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.CommitBlockPResponse.Builder
 
build() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
build() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
build() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
build() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
build() - Method in class alluxio.grpc.ConfigProperties.Builder
 
build() - Method in class alluxio.grpc.ConfigProperty.Builder
 
build() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
build() - Method in class alluxio.grpc.CopyRequest.Builder
 
build() - Method in class alluxio.grpc.CopyResponse.Builder
 
build() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
build() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
build() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
build() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
build() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
build() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
build() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
build() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
build() - Method in class alluxio.grpc.DeletePOptions.Builder
 
build() - Method in class alluxio.grpc.DeletePRequest.Builder
 
build() - Method in class alluxio.grpc.DeletePResponse.Builder
 
build() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.ErrorInfo.Builder
 
build() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
build() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
build() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
build() - Method in class alluxio.grpc.File.Builder
 
build() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
build() - Method in class alluxio.grpc.FileFailure.Builder
 
build() - Method in class alluxio.grpc.FileInfo.Builder
 
build() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
build() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
build() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
build() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
build() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
 
build() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
 
build() - Method in class alluxio.grpc.FreePOptions.Builder
 
build() - Method in class alluxio.grpc.FreePRequest.Builder
 
build() - Method in class alluxio.grpc.FreePResponse.Builder
 
build() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
build() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
build() - Method in class alluxio.grpc.FsOpPId.Builder
 
build() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
build() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
build() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
build() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
build() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
build() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
build() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
build() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
build() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
build() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
build() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
build() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
build() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
build() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
build() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
build() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
build() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
build() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
build() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
build() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
build() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
build() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
build() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
build() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
build() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
build() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
build() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
build() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
build() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
build() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
build() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
build() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
build() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
build() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
build() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
build() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
build() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
build() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
build() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
build() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
build() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
build() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
build() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
build() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
build() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
build() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
build() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
build() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
build() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
build() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
build() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
build() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
build() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
build() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
build() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
build() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
build() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
build() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
build() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
build() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
build() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
build() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
build() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
build() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
build() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
build() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
build() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
build() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
build() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
build() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
build() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
build() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
build() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
build() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
build() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
build() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
build() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
build() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
build() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
build() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
build() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
build() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
build() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
build() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
build() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
build() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
build() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
build() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
build() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
build() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
build() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
build() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
build() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
build() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
build() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
build() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
build() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
build() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
build() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
build() - Method in class alluxio.grpc.GrpcChannelBuilder
Creates an authenticated channel of type GrpcChannel.
build() - Method in class alluxio.grpc.GrpcServerBuilder
Build the server.
build(Supplier<NodeState>) - Method in class alluxio.grpc.GrpcServerBuilder
Build the server.
build() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
build() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
build() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
build() - Method in class alluxio.grpc.JobCommand.Builder
 
build() - Method in class alluxio.grpc.JobDescription.Builder
 
build() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
build() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
build() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
build() - Method in class alluxio.grpc.JobInfo.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
 
build() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
build() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
build() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceStub
 
build() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceStub
 
build() - Method in class alluxio.grpc.JobProgress.Builder
 
build() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
build() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
build() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
build() - Method in class alluxio.grpc.JobUnused.Builder
 
build() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
 
build() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
build() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
build() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
build() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
build() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
build() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
build() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
build() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
build() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
build() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
build() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
build() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
build() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
build() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
build() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
build() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
build() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
build() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
build() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
build() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
build() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
build() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
build() - Method in class alluxio.grpc.LoadRequest.Builder
 
build() - Method in class alluxio.grpc.LoadResponse.Builder
 
build() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
build() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
build() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
build() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
build() - Method in class alluxio.grpc.MasterInfo.Builder
 
build() - Method in class alluxio.grpc.MasterVersion.Builder
 
build() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
build() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceStub
 
build() - Method in class alluxio.grpc.Metric.Builder
 
build() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
build() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
build() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub
 
build() - Method in class alluxio.grpc.MetricValue.Builder
 
build() - Method in class alluxio.grpc.MountPointInfo.Builder
 
build() - Method in class alluxio.grpc.MountPOptions.Builder
 
build() - Method in class alluxio.grpc.MountPRequest.Builder
 
build() - Method in class alluxio.grpc.MountPResponse.Builder
 
build() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
build() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
build() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
build() - Method in class alluxio.grpc.MoveRequest.Builder
 
build() - Method in class alluxio.grpc.MoveResponse.Builder
 
build() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
build() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
build() - Method in class alluxio.grpc.NetAddress.Builder
 
build() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
build() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
build() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
build() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
build() - Method in class alluxio.grpc.PAcl.Builder
 
build() - Method in class alluxio.grpc.PAclEntry.Builder
 
build() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
build() - Method in class alluxio.grpc.PersistFile.Builder
 
build() - Method in class alluxio.grpc.PMode.Builder
 
build() - Method in class alluxio.grpc.PolicyInfo.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
 
build() - Method in class alluxio.grpc.PolicyStatus.Builder
 
build() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
build() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
build() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
build() - Method in class alluxio.grpc.ProxyStatus.Builder
 
build() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceStub
 
build() - Method in class alluxio.grpc.ReadRequest.Builder
 
build() - Method in class alluxio.grpc.ReadResponse.Builder
 
build() - Method in class alluxio.grpc.RegisterCommand.Builder
 
build() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
build() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
build() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
build() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
build() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
build() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
build() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
build() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
build() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
build() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
build() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
build() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
build() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
build() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
build() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
build() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
build() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
build() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
build() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
build() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
build() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
build() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
build() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
build() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
build() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
build() - Method in class alluxio.grpc.RenamePOptions.Builder
 
build() - Method in class alluxio.grpc.RenamePRequest.Builder
 
build() - Method in class alluxio.grpc.RenamePResponse.Builder
 
build() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
build() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
build() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
build() - Method in class alluxio.grpc.RetryInfo.Builder
 
build() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
build() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
build() - Method in class alluxio.grpc.Route.Builder
 
build() - Method in class alluxio.grpc.RouteFailure.Builder
 
build() - Method in class alluxio.grpc.RunPOptions.Builder
 
build() - Method in class alluxio.grpc.RunPRequest.Builder
 
build() - Method in class alluxio.grpc.RunPResponse.Builder
 
build() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
build() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceStub
 
build() - Method in class alluxio.grpc.SaslMessage.Builder
 
build() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
build() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
build() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceStub
 
build() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
build() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
build() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
build() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
build() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
build() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
build() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
build() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
build() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
build() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
build() - Method in class alluxio.grpc.SnapshotData.Builder
 
build() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
build() - Method in class alluxio.grpc.StatusSummary.Builder
 
build() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
build() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
build() - Method in class alluxio.grpc.StorageList.Builder
 
build() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
build() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
build() - Method in class alluxio.grpc.SubmitOptions.Builder
 
build() - Method in class alluxio.grpc.SubmitRequest.Builder
 
build() - Method in class alluxio.grpc.SubmitResponse.Builder
 
build() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
build() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
build() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
build() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
build() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
build() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
build() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
build() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
build() - Method in class alluxio.grpc.table.Constraint.Builder
 
build() - Method in class alluxio.grpc.table.Database.Builder
 
build() - Method in class alluxio.grpc.table.Date.Builder
 
build() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
build() - Method in class alluxio.grpc.table.Decimal.Builder
 
build() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
build() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
build() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
build() - Method in class alluxio.grpc.table.Domain.Builder
 
build() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
build() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
build() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
build() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
build() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
build() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
build() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
build() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
build() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
build() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
build() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
build() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
build() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
build() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
build() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
build() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
build() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
build() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
build() - Method in class alluxio.grpc.table.Layout.Builder
 
build() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
build() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
build() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
build() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
build() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
build() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
build() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
build() - Method in class alluxio.grpc.table.Partition.Builder
 
build() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
build() - Method in class alluxio.grpc.table.Range.Builder
 
build() - Method in class alluxio.grpc.table.RangeSet.Builder
 
build() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
build() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
build() - Method in class alluxio.grpc.table.Schema.Builder
 
build() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
build() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
build() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
build() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
build() - Method in class alluxio.grpc.table.TableInfo.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
build() - Method in class alluxio.grpc.table.Transformation.Builder
 
build() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
build() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
build() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
build() - Method in class alluxio.grpc.table.Value.Builder
 
build() - Method in class alluxio.grpc.TierList.Builder
 
build() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
build() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
build() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
build() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
build() - Method in class alluxio.grpc.TransportMessage.Builder
 
build() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
build() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
build() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
build() - Method in class alluxio.grpc.UfsInfo.Builder
 
build() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
build() - Method in class alluxio.grpc.UfsStatus.Builder
 
build() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
build() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
build() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
build() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
build() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
build() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
build() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
build() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
build() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
build() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
build() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
build() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
build() - Method in class alluxio.grpc.WorkerInfo.Builder
 
build() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
build() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
build() - Method in class alluxio.grpc.WriteOptions.Builder
 
build() - Method in class alluxio.grpc.WriteRequest.Builder
 
build() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
build() - Method in class alluxio.grpc.WriteResponse.Builder
 
build() - Method in class alluxio.job.JobDescription.Builder
build job description.
build() - Method in class alluxio.master.CoreMasterContext.Builder
 
build(CommonUtils.ProcessType) - Method in class alluxio.master.journal.JournalSystem.Builder
 
build() - Method in class alluxio.master.MasterClientContextBuilder
 
build() - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
build() - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
 
build() - Method in class alluxio.master.metastore.ReadOption.Builder
 
build() - Method in class alluxio.metrics.MetricKey.Builder
Creates and registers the Metric key.
build() - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
build() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
build() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
build() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
build() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
build() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
build() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
build() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
build() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
build() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
build() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
build() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
build() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
build() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
build() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
build() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
build() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
build() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
build() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
build() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
build() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
build() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
build() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
build() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
build() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
build() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
build() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
build() - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
build() - Method in class alluxio.security.authorization.AclEntry.Builder
 
build(String, boolean) - Static method in class alluxio.util.ThreadFactoryUtils
Creates a ThreadFactory that spawns off threads.
build() - Method in class alluxio.util.UnixMountInfo.Builder
 
build() - Method in class alluxio.util.UnixMountInfo.Options.Builder
 
build() - Method in class alluxio.wire.Configuration.Builder
 
build() - Method in class alluxio.worker.job.JobMasterClientContextBuilder
Builds the configuration, creating an instance of MasterInquireClient if none is specified.
BUILD_VERSION_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
BUILD_VERSION = 11;
buildCanonicalRequest(String, String, String, String, Map<String, String>, Map<String, String>, boolean) - Static method in class alluxio.s3.signature.StringToSignProducer
Convert request info to a format string.
Builder() - Constructor for class alluxio.client.file.options.FileSystemOptions.Builder
 
Builder(PropertyKey.Template, Object...) - Constructor for class alluxio.conf.PropertyKey.Builder
 
Builder(PropertyKey.PropertyType, PropertyKey.Template, Object...) - Constructor for class alluxio.conf.PropertyKey.Builder
 
Builder(PropertyKey.PropertyType, Optional<String>, PropertyKey.Template, Object...) - Constructor for class alluxio.conf.PropertyKey.Builder
 
Builder() - Constructor for class alluxio.fuse.options.FuseOptions.Builder
Creates a new builder with default settings.
Builder() - Constructor for class alluxio.master.CoreMasterContext.Builder
 
Builder() - Constructor for class alluxio.master.journal.JournalSystem.Builder
Creates a new journal system builder.
Builder(AlluxioConfiguration) - Constructor for class alluxio.master.MasterHealthCheckClient.Builder
Constructs the builder with default values.
Builder() - Constructor for class alluxio.master.metastore.caching.CacheConfiguration.Builder
 
Builder() - Constructor for class alluxio.master.metastore.ReadOption.Builder
 
Builder(String) - Constructor for class alluxio.metrics.MetricKey.Builder
 
builder() - Static method in class alluxio.retry.ExponentialTimeBoundedRetry
 
Builder() - Constructor for class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
Builder() - Constructor for class alluxio.security.authorization.AclEntry.Builder
Creates a new builder where type is null, subject is an empty string, and no action is permitted.
Builder() - Constructor for class alluxio.util.UnixMountInfo.Builder
Constructs a new Unix mount info builder.
Builder() - Constructor for class alluxio.util.UnixMountInfo.Options.Builder
Constructs a new unix mount info options builder.
Builder() - Constructor for class alluxio.wire.Configuration.Builder
 
buildExecutorService(ExecutorServiceBuilder.RpcExecutorHost) - Static method in class alluxio.executor.ExecutorServiceBuilder
Creates an ExecutorService for given Alluxio process dynamically by configuration.
buildExecutorService(ExecutorServiceBuilder.RpcExecutorHost, Counter) - Static method in class alluxio.executor.ExecutorServiceBuilder
Creates an ExecutorService for given Alluxio process dynamically by configuration.
buildFileInfoFromUfsStatus(UfsStatus, String) - Method in class alluxio.worker.dora.PagedDoraWorker
Build FileInfo from UfsStatus and UFS full Path.
buildFileStatusFromUfsStatus(UfsStatus, String) - Method in class alluxio.worker.dora.PagedDoraWorker
Build FileStatus from UfsStatus and UFS full Path.
buildFjp(String, boolean) - Static method in class alluxio.util.ThreadFactoryUtils
Creates a ForkJoinPool.ForkJoinWorkerThreadFactory that spawns off threads for ForkJoinPool.
buildFromStatuses(String, List<URIStatus>) - Static method in class alluxio.proxy.s3.ListMultipartUploadsResult
 
buildPartial() - Method in class alluxio.grpc.ActionInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.BackupPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.BackupPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.BackupPStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.Block.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockIdList.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockLocation.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
buildPartial() - Method in class alluxio.grpc.BuildVersion.Builder
 
buildPartial() - Method in class alluxio.grpc.CacheRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CacheResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CancelPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CancelPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CancelPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CheckResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.Chunk.Builder
 
buildPartial() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ClientMetrics.Builder
 
buildPartial() - Method in class alluxio.grpc.CmdProgress.Builder
 
buildPartial() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
buildPartial() - Method in class alluxio.grpc.CmdSummary.Builder
 
buildPartial() - Method in class alluxio.grpc.Command.Builder
 
buildPartial() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
buildPartial() - Method in class alluxio.grpc.ConfigProperties.Builder
 
buildPartial() - Method in class alluxio.grpc.ConfigProperty.Builder
 
buildPartial() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CopyRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CopyResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.DeletePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.DeletePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.DeletePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.ErrorInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.File.Builder
 
buildPartial() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.FileFailure.Builder
 
buildPartial() - Method in class alluxio.grpc.FileInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
buildPartial() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.FreePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.FreePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.FreePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.FsOpPId.Builder
 
buildPartial() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
buildPartial() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
buildPartial() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
buildPartial() - Method in class alluxio.grpc.JobCommand.Builder
 
buildPartial() - Method in class alluxio.grpc.JobDescription.Builder
 
buildPartial() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.JobInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.JobProgress.Builder
 
buildPartial() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
buildPartial() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
buildPartial() - Method in class alluxio.grpc.JobUnused.Builder
 
buildPartial() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
buildPartial() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.LoadResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
buildPartial() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.MasterInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.MasterVersion.Builder
 
buildPartial() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
buildPartial() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
buildPartial() - Method in class alluxio.grpc.Metric.Builder
 
buildPartial() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.MetricValue.Builder
 
buildPartial() - Method in class alluxio.grpc.MountPointInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.MountPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.MountPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.MountPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.MoveRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.MoveResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.NetAddress.Builder
 
buildPartial() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.PAcl.Builder
 
buildPartial() - Method in class alluxio.grpc.PAclEntry.Builder
 
buildPartial() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.PersistFile.Builder
 
buildPartial() - Method in class alluxio.grpc.PMode.Builder
 
buildPartial() - Method in class alluxio.grpc.PolicyInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.PolicyStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ProxyStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.ReadRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ReadResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterCommand.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RenamePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RenamePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RenamePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RetryInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.Route.Builder
 
buildPartial() - Method in class alluxio.grpc.RouteFailure.Builder
 
buildPartial() - Method in class alluxio.grpc.RunPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.RunPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.RunPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
buildPartial() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.SaslMessage.Builder
 
buildPartial() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
buildPartial() - Method in class alluxio.grpc.SnapshotData.Builder
 
buildPartial() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
buildPartial() - Method in class alluxio.grpc.StatusSummary.Builder
 
buildPartial() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.StorageList.Builder
 
buildPartial() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.SubmitOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.SubmitRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.SubmitResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
buildPartial() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Constraint.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Database.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Date.Builder
 
buildPartial() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Decimal.Builder
 
buildPartial() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Domain.Builder
 
buildPartial() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
buildPartial() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
buildPartial() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Layout.Builder
 
buildPartial() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
buildPartial() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
buildPartial() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
buildPartial() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
buildPartial() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
buildPartial() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Partition.Builder
 
buildPartial() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Range.Builder
 
buildPartial() - Method in class alluxio.grpc.table.RangeSet.Builder
 
buildPartial() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Schema.Builder
 
buildPartial() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
buildPartial() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.table.TableInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Transformation.Builder
 
buildPartial() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.table.Value.Builder
 
buildPartial() - Method in class alluxio.grpc.TierList.Builder
 
buildPartial() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
buildPartial() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.TransportMessage.Builder
 
buildPartial() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.UfsInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.UfsStatus.Builder
 
buildPartial() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
buildPartial() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
buildPartial() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
buildPartial() - Method in class alluxio.grpc.WorkerInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
buildPartial() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
buildPartial() - Method in class alluxio.grpc.WriteOptions.Builder
 
buildPartial() - Method in class alluxio.grpc.WriteRequest.Builder
 
buildPartial() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
buildPartial() - Method in class alluxio.grpc.WriteResponse.Builder
 
buildPartial() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
buildPartial() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
buildPartial() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
buildPartial() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
buildPartial() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
buildPartial() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
buildPartial() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
buildPartial() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
buildPartial() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
buildPartial() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
buildPartial() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
buildPartial() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
buildUnregistered() - Method in class alluxio.conf.PropertyKey.Builder
Creates the property key without registering it with default property list.
BuildVersion - Class in alluxio.grpc
Protobuf type alluxio.grpc.BuildVersion
BuildVersion.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.BuildVersion
BUILDVERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPOptions
 
BUILDVERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
BuildVersionOrBuilder - Interface in alluxio.grpc
 
BuiltinBitSet - Class in alluxio.collections
This class is a wrapper of java's builtin BitSet.
BuiltinBitSet(int) - Constructor for class alluxio.collections.BuiltinBitSet
Creates a new bit set.
BusyException - Exception in alluxio.exception
Thrown when the system is busy.
BusyException() - Constructor for exception alluxio.exception.BusyException
Constructs a new busy exception.
BYPASSDELEGATION_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPOptions
 
byteArray() - Method in class alluxio.file.ByteArrayTargetBuffer
 
byteArray() - Method in class alluxio.file.ByteBufferTargetBuffer
 
byteArray() - Method in class alluxio.file.NettyBufTargetBuffer
 
byteArray() - Method in interface alluxio.file.ReadTargetBuffer
 
ByteArrayTargetBuffer - Class in alluxio.file
Target buffer backed by bytes array for zero-copy read from page store.
ByteArrayTargetBuffer(byte[], int) - Constructor for class alluxio.file.ByteArrayTargetBuffer
Constructor.
byteArrayToHexString(byte[]) - Static method in class alluxio.util.FormatUtils
Parses a byte array into a space separated hex string where each byte is represented in the format 0x%02x.
byteArrayToHexString(byte[], String, String) - Static method in class alluxio.util.FormatUtils
Parses a byte array into a hex string where each byte is represented in the format %02x.
byteBuffer() - Method in class alluxio.file.ByteArrayTargetBuffer
 
byteBuffer() - Method in class alluxio.file.ByteBufferTargetBuffer
 
byteBuffer() - Method in class alluxio.file.NettyBufTargetBuffer
 
byteBuffer() - Method in interface alluxio.file.ReadTargetBuffer
 
ByteBufferResourcePool - Class in alluxio.underfs
A simple byte buffer resource pool.
ByteBufferResourcePool(int, int) - Constructor for class alluxio.underfs.ByteBufferResourcePool
Creates an instance.
ByteBufferTargetBuffer - Class in alluxio.file
Target buffer backed by nio ByteBuffer for zero-copy read from page store.
ByteBufferTargetBuffer(ByteBuffer) - Constructor for class alluxio.file.ByteBufferTargetBuffer
Constructor.
byteBufferToString(ByteBuffer) - Static method in class alluxio.util.FormatUtils
Parses a ByteBuffer into a String.
byteChannel() - Method in class alluxio.file.ByteArrayTargetBuffer
 
byteChannel() - Method in class alluxio.file.ByteBufferTargetBuffer
 
byteChannel() - Method in class alluxio.file.NettyBufTargetBuffer
 
byteChannel() - Method in interface alluxio.file.ReadTargetBuffer
 
ByteIOUtils - Class in alluxio.util.io
A collection of utility functions to read/write primitive values from/to a byte array.
bytes() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
bytes() - Method in interface alluxio.client.file.cache.PageMetaStore
 
bytes(CacheScope) - Method in class alluxio.client.file.cache.QuotaPageMetaStore
 
BYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCapacityBytesPResponse
 
BYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.GetUsedBytesPResponse
 
BYTES_IN_INTEGER - Static variable in class alluxio.Constants
 
BYTES_SKIPPED_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileResponse
 
byteToInt(byte) - Static method in class alluxio.util.io.BufferUtils
Converts a byte to an integer.

C

cache(CacheRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Caches a block.
cache(CacheRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
cache(CacheRequest, StreamObserver<CacheResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
cache(CacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
cache(CacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
cache(CacheRequest, StreamObserver<CacheResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
Cache<K,V> - Class in alluxio.master.metastore.caching
Base class for write-back caches which asynchronously evict entries to backing stores.
Cache(CacheConfiguration, String, MetricKey, MetricKey, MetricKey, MetricKey, MetricKey) - Constructor for class alluxio.master.metastore.caching.Cache
 
Cache - Class in alluxio.proto.client
 
cache(CacheRequest) - Method in interface alluxio.worker.block.BlockWorker
Submits the cache request to cache manager to execute.
Cache.Entry - Class in alluxio.master.metastore.caching
 
Cache.PPageStoreCommonOptions - Class in alluxio.proto.client
Protobuf type alluxio.proto.client.PPageStoreCommonOptions
Cache.PPageStoreCommonOptions.Builder - Class in alluxio.proto.client
Protobuf type alluxio.proto.client.PPageStoreCommonOptions
Cache.PPageStoreCommonOptionsOrBuilder - Interface in alluxio.proto.client
 
Cache.PRocksPageStoreOptions - Class in alluxio.proto.client
Protobuf type alluxio.proto.client.PRocksPageStoreOptions
Cache.PRocksPageStoreOptions.Builder - Class in alluxio.proto.client
Protobuf type alluxio.proto.client.PRocksPageStoreOptions
Cache.PRocksPageStoreOptionsOrBuilder - Interface in alluxio.proto.client
 
CACHE_CLEAN_ERRORS - Static variable in class alluxio.client.file.cache.PageStore.Metrics
Number of failures when cleaning out the existing cache directory to initialize a new cache.
CACHE_PROMOTE_VALUE - Static variable in enum alluxio.grpc.ReadPType
CACHE_PROMOTE = 3;
CACHE_THROUGH_VALUE - Static variable in enum alluxio.grpc.WritePType
CACHE_THROUGH = 3;
CACHE_UFS_SESSION_ID - Static variable in class alluxio.Sessions
 
CACHE_VALUE - Static variable in enum alluxio.grpc.ReadPType
CACHE = 2;
CACHE_WORKER_SESSION_ID - Static variable in class alluxio.Sessions
 
CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
CacheConfiguration - Class in alluxio.master.metastore.caching
Cache configuration.
CacheConfiguration.Builder - Class in alluxio.master.metastore.caching
Cache configuration builder.
CacheContext - Class in alluxio.client.file
Cache related context.
CacheContext() - Constructor for class alluxio.client.file.CacheContext
Expected to be inherited in PrestoDB or other local cache caller.
CacheContext.StatsUnit - Enum in alluxio.client.file
Stats Unit.
CachedGroupMapping - Class in alluxio.security.group
Class to map user to groups.
CachedGroupMapping(GroupMappingService, long) - Constructor for class alluxio.security.group.CachedGroupMapping
Constructor with specified GroupMappingService.
cachedThreadPool(String) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name.
CacheEvictor - Interface in alluxio.client.file.cache.evictor
Interface for client-side cache eviction policy.
CacheEvictorOptions - Class in alluxio.client.file.cache.evictor
Options for initiating cache evictor.
CacheEvictorOptions() - Constructor for class alluxio.client.file.cache.evictor.CacheEvictorOptions
 
CacheFilter - Interface in alluxio.client.file.cache.filter
The Cache Filter interface which is used to determine whether a particular file (URI) needs to be cached.
CacheManager - Interface in alluxio.client.file.cache
Interface for managing cached pages.
CacheManager.Factory - Class in alluxio.client.file.cache
Factory class to get or create a CacheManager.
CacheManager.State - Enum in alluxio.client.file.cache
State of a cache.
CacheManagerOptions - Class in alluxio.client.file.cache
Options for initiating local cache manager.
CacheManagerOptions() - Constructor for class alluxio.client.file.cache.CacheManagerOptions
Constructor.
CacheManagerWithShadowCache - Class in alluxio.client.file.cache
A wrapper class of CacheManager with shadow cache.
CacheManagerWithShadowCache(CacheManager, AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.CacheManagerWithShadowCache
 
CacheManagerWithShadowCache.PageIdFunnel - Enum in alluxio.client.file.cache
Funnel for PageId.
cacheOperation(OperationId) - Method in class alluxio.master.file.meta.InodeTree
Used to mark an operation as complete in retry-cache.
cacheOperation(OperationId) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Used to mark an operation as complete in retry-cache.
CachePerThreadContext - Class in alluxio.client.file.cache.context
A per-thread cache context for local cache.
CachePerThreadContext() - Constructor for class alluxio.client.file.cache.context.CachePerThreadContext
 
CacheQuota - Class in alluxio.client.quota
Data structure that stores and returns cache size in number of bytes associated with a cache scope.
CacheQuota(Map<CacheScope.Level, Long>) - Constructor for class alluxio.client.quota.CacheQuota
 
CacheQuota() - Constructor for class alluxio.client.quota.CacheQuota
Empty cache quota.
CacheRequest - Class in alluxio.grpc
Request for caching a block synchronously/asynchronously next available id: 7
CacheRequest.Builder - Class in alluxio.grpc
Request for caching a block synchronously/asynchronously next available id: 7
CacheRequestOrBuilder - Interface in alluxio.grpc
 
CacheResponse - Class in alluxio.grpc
Response for an async cache request
CacheResponse.Builder - Class in alluxio.grpc
Response for an async cache request
CacheResponseOrBuilder - Interface in alluxio.grpc
 
CacheScope - Class in alluxio.client.quota
This class defines "Scope" of a cache quota.
CacheScope.Level - Enum in alluxio.client.quota
Level of a scope.
CACHESIZE_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
CacheStatus - Interface in alluxio.client.file.cache
Mixin interface for various cache status info.
CacheUsage - Interface in alluxio.client.file.cache
Cache usage.
CacheUsage.DirPartition - Class in alluxio.client.file.cache
Partition on a particular cache directory.
CacheUsage.FilePartition - Class in alluxio.client.file.cache
Partition on a particular file.
CacheUsage.PartitionDescriptor<T> - Interface in alluxio.client.file.cache
Partition descriptor.
CacheUsage.ScopePartition - Class in alluxio.client.file.cache
Partition on a cache scope.
CacheUsageView - Interface in alluxio.client.file.cache
Immutable view of cache usage stats.
CacheUsageView.ImmutableCacheUsageView - Class in alluxio.client.file.cache
Immutable holder of cache stats.
CachingInodeStore - Class in alluxio.master.metastore.caching
An inode store which caches inode tree metadata and delegates to another inode store for cache misses.
CachingInodeStore(InodeStore, InodeLockManager) - Constructor for class alluxio.master.metastore.caching.CachingInodeStore
 
calculateCost(String, Map<String, Long>) - Static method in class alluxio.master.metrics.CloudCostUtils
Calculate the saved cost from the perUfs Operations saved map.
calculateObjectSize(Object) - Method in class alluxio.util.ObjectSizeCalculator
Given an object, returns the total allocated size, in bytes, of the object and all other objects reachable from it.
calculatePercentiles() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
From the collected operation data, calculates 100 percentiles.
call() - Method in interface alluxio.AbstractClient.RpcCallable
The task where RPC happens.
call() - Method in class alluxio.cli.BasicCheckpoint
 
call() - Method in class alluxio.cli.BasicNonByteBufferOperations
 
call() - Method in class alluxio.cli.BasicOperations
 
call(Logger, AlluxioFuseUtils.FuseCallable, String, String, Object...) - Static method in class alluxio.fuse.AlluxioFuseUtils
Calls the given AlluxioFuseUtils.FuseCallable and returns its result.
call() - Method in interface alluxio.fuse.AlluxioFuseUtils.FuseCallable
The RPC implementation.
call() - Method in interface alluxio.membership.AlluxioEtcdClient.EtcdUtilCallable
The task where logics to communicate with etcd happens.
call(NettyRPCContext, ProtoMessage) - Static method in class alluxio.network.netty.NettyRPC
Sends a request and waits for a response.
call() - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
 
call(String, S3RestUtils.RestCallable<T>) - Static method in class alluxio.proxy.s3.S3RestUtils
Calls the given S3RestUtils.RestCallable and handles any exceptions thrown.
call() - Method in interface alluxio.proxy.s3.S3RestUtils.RestCallable
The REST endpoint implementation.
call(RestUtils.RestCallable<T>, AlluxioConfiguration, Map<String, Object>) - Static method in class alluxio.RestUtils
Calls the given RestUtils.RestCallable and handles any exceptions thrown.
call(RestUtils.RestCallable<T>, AlluxioConfiguration) - Static method in class alluxio.RestUtils
Call response.
call() - Method in interface alluxio.RestUtils.RestCallable
The REST endpoint implementation.
call(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, String, StreamObserver<T>, Object...) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallableThrowsIOException and handles any exceptions thrown.
call(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, boolean, String, StreamObserver<T>, Object...) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallableThrowsIOException and handles any exceptions thrown.
call() - Method in interface alluxio.RpcUtils.NettyRPCCallable
The RPC implementation.
call() - Method in interface alluxio.RpcUtils.RpcCallableThrowsIOException
The RPC implementation.
call() - Method in interface alluxio.RpcUtils.StreamingRpcCallable
The RPC implementation.
call(String, NettyRestUtils.RestCallable<T>) - Static method in class alluxio.s3.NettyRestUtils
Calls the given NettyRestUtils.RestCallable and handles any exceptions thrown.
call() - Method in interface alluxio.s3.NettyRestUtils.RestCallable
The REST endpoint implementation.
callAndReturn(Logger, RpcUtils.RpcCallableThrowsIOException<T>, String, boolean, String, Object...) - Static method in class alluxio.RpcUtils
Calls the given RpcUtils.RpcCallableThrowsIOException and returns its result.
CallTracker - Interface in alluxio.master.file.contexts
An interface for RPC level call tracking.
CallTracker.Type - Enum in alluxio.master.file.contexts
Defines call-tracker types.
cancel() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
 
cancel() - Method in class alluxio.client.block.stream.GrpcBlockingStream
Cancels the stream.
cancel() - Method in class alluxio.client.block.stream.GrpcDataWriter
 
cancel() - Method in class alluxio.client.block.stream.NettyDataWriter
 
cancel() - Method in interface alluxio.client.Cancelable
Cancels an operation.
cancel() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
cancel() - Method in class alluxio.client.file.DoraFileOutStream
 
cancel() - Method in class alluxio.client.file.FileOutStream
Aborts the output stream.
cancel() - Method in class alluxio.client.file.ufs.UfsFileOutStream
 
cancel(long) - Method in interface alluxio.client.job.JobMasterClient
Cancels the given job.
cancel(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
cancel(boolean) - Method in class alluxio.concurrent.jsr.CompletableFuture
If not already completed, completes this CompletableFuture with a CancellationException.
cancel(boolean) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Attempts to cancel execution of this task.
cancel(CancelPRequest, StreamObserver<CancelPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Cancels the given job.
cancel(CancelPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Cancels the given job.
cancel(CancelPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Cancels the given job.
cancel(CancelPRequest, StreamObserver<CancelPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Cancels the given job.
CANCEL - Static variable in class alluxio.job.ServiceConstants
 
cancel(long) - Method in class alluxio.master.job.JobMaster
Cancels a job.
cancel(long) - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
Cancels a job.
cancel(CancelPRequest, StreamObserver<CancelPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
cancel() - Method in class alluxio.master.job.plan.PlanCoordinator
Cancels the current job.
cancel(long) - Method in class alluxio.master.job.workflow.WorkflowTracker
Cancels a job with a particular job id.
cancel() - Method in class alluxio.master.journal.AbstractCatchupThread
Cancels catching up gracefully.
cancel() - Method in class alluxio.master.journal.CatchupFuture
Cancels catchup progress gracefully.
cancel() - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
Cancel an ongoing read request.
CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
CANCEL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
Cancelable - Interface in alluxio.client
This interface should be implemented by all Alluxio output streams which support aborting the temporary data that has been written.
cancelAbort(FileSystem, FileSystem, String, String, String) - Static method in class alluxio.proxy.s3.MultipartUploadCleaner
Cancel schedule task.
cancelAllPrefetch() - Method in class alluxio.underfs.UfsStatusCache
Interrupts and cancels any currently running prefetch jobs.
CANCELED_VALUE - Static variable in enum alluxio.grpc.Status
CANCELED = 2;
CanceledException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
CanceledException(String) - Constructor for exception alluxio.exception.status.CanceledException
 
CanceledException(Throwable) - Constructor for exception alluxio.exception.status.CanceledException
 
CanceledException(String, Throwable) - Constructor for exception alluxio.exception.status.CanceledException
 
CANCELLED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
Canceled indicates the operation was cancelled (typically by the caller).
CancelledException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
CancelledException(String) - Constructor for exception alluxio.exception.status.CancelledException
 
CancelledException(Throwable) - Constructor for exception alluxio.exception.status.CancelledException
 
CancelledException(String, Throwable) - Constructor for exception alluxio.exception.status.CancelledException
 
CancelledResponseEvent - Class in alluxio.client.file.dora.netty.event
Cancelled response event.
CancelledResponseEvent() - Constructor for class alluxio.client.file.dora.netty.event.CancelledResponseEvent
Cancelled response event.
CancelledRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the service is cancelled or interrupted (typically by the caller).
CancelledRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.CancelledRuntimeException
Constructor.
CancelledRuntimeException(String) - Constructor for exception alluxio.exception.runtime.CancelledRuntimeException
Constructor.
CancelPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelPOptions
CancelPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelPOptions
CancelPOptionsOrBuilder - Interface in alluxio.grpc
 
CancelPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelPRequest
CancelPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelPRequest
CancelPRequestOrBuilder - Interface in alluxio.grpc
 
CancelPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelPResponse
CancelPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelPResponse
CancelPResponseOrBuilder - Interface in alluxio.grpc
 
cancelRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
cancelRequest(BlockWriteRequestContext) - Method in class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
 
cancelRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
cancelTask(long, long) - Method in class alluxio.worker.job.task.TaskExecutorManager
Cancels the given task.
CancelTaskCommand - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelTaskCommand
CancelTaskCommand.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CancelTaskCommand
CANCELTASKCOMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobCommand
 
CancelTaskCommandOrBuilder - Interface in alluxio.grpc
 
CANDIDATES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.EquatableValueSet
 
canHandleShutdownHooks() - Static method in class alluxio.jnifuse.utils.SecurityUtils
 
canonicalizeUri(URI) - Method in class alluxio.hadoop.AbstractFileSystem
 
CANREGISTERAGAIN_FIELD_NUMBER - Static variable in class alluxio.grpc.DecommissionWorkerPOptions
 
CanUnbuffer - Interface in alluxio.client
indicate that InputStream can clear their buffers on request.
canUseReservedSpace() - Method in class alluxio.worker.block.AllocateOptions
 
capacity() - Method in interface alluxio.client.file.cache.CacheUsageView
Total capacity of the cache.
capacity() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
Capacity - Class in alluxio.wire
Class that represents the available, free, and total capacity.
Capacity() - Constructor for class alluxio.wire.Capacity
Creates a new instance of Capacity.
CAPACITY_BYTES_ON_TIERS_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
CAPACITY_BYTES_ON_TIERS = 2;
CAPACITY_BYTES_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
CAPACITY_BYTES = 1;
CAPACITYBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
CAPACITYBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
CAPACITYBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPOptions
 
CAPACITYBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
CAPACITYBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
castToIOException(Throwable) - Static method in class alluxio.util.CommonUtils
Casts a Throwable to an IOException.
catchup(Map<String, Long>) - Method in interface alluxio.master.journal.JournalSystem
Initiates a catching up of journals to given sequences.
catchup(Map<String, Long>) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
catchup(long) - Method in class alluxio.master.journal.raft.BufferedJournalApplier
Initiates catching up of the applier to a target sequence.
catchup(long) - Method in class alluxio.master.journal.raft.JournalStateMachine
Initiates catching up of masters to given sequence.
catchup(Map<String, Long>) - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
catchup(long) - Method in class alluxio.master.journal.ufs.UfsJournal
Initiates catching up of the journal up to given sequence.
catchup(Map<String, Long>) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
CatchupFuture - Class in alluxio.master.journal
Used to track and cancel journal advancing.
CatchupFuture(AbstractCatchupThread) - Constructor for class alluxio.master.journal.CatchupFuture
Creates a tracker for given catchup thread.
CatCommand - Class in alluxio.cli.fs.command
Prints the file's contents to the console.
CatCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CatCommand
 
CDH_PREFIX - Static variable in class alluxio.cli.hdfs.HdfsVersionValidationTask
 
CephfsHadoopUnderFileSystem - Class in alluxio.underfs.cephfshadoop
Cephfs-Hadoop UnderFileSystem implementation.
CephfsHadoopUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystem
Constructs a new Cephfs-Hadoop UnderFileSystem.
CephfsHadoopUnderFileSystemFactory - Class in alluxio.underfs.cephfshadoop
Factory for creating CephfsHadoopUnderFileSystem.
CephfsHadoopUnderFileSystemFactory() - Constructor for class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
 
CephFSUnderFileSystem - Class in alluxio.underfs.cephfs
CephFS UnderFileSystem implementation.
CephFSUnderFileSystem(AlluxioURI, CephMount, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.cephfs.CephFSUnderFileSystem
Constructs a new CephFS UnderFileSystem.
CephFSUnderFileSystemFactory - Class in alluxio.underfs.cephfs
Factory for creating CephFSUnderFileSystem.
CephFSUnderFileSystemFactory() - Constructor for class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
CephInputStream - Class in alluxio.underfs.cephfs
A stream for reading a file from CephFS.
CephInputStream(CephMount, int, long) - Constructor for class alluxio.underfs.cephfs.CephInputStream
Create a new CephInputStream.
CephOutputStream - Class in alluxio.underfs.cephfs
A stream for writing a file into CephFS.
CephOutputStream(CephMount, int) - Constructor for class alluxio.underfs.cephfs.CephOutputStream
Construct the CephOutputStream.
CephSeekableInputStream - Class in alluxio.underfs.cephfs
The input stream of CEPHFS as under filesystem.
CHALLENGE_VALUE - Static variable in enum alluxio.grpc.SaslMessageType
CHALLENGE = 0;
changeLocalFileGroup(String, String) - Static method in class alluxio.util.io.FileUtils
Changes the local file's group.
changeLocalFilePermission(String, String) - Static method in class alluxio.util.io.FileUtils
Changes local file's permission.
changeLocalFileToFullPermission(String) - Static method in class alluxio.util.io.FileUtils
Changes local file's permission to be "rwxrwxrwx".
changeLocalFileUser(String, String) - Static method in class alluxio.util.io.FileUtils
Changes the local file's user.
CHANNEL_TYPE - Static variable in class alluxio.util.network.NettyUtils
 
ChannelAdapters - Class in alluxio.util.io
Channel adapters.
ChannelAuthenticationScheme - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.sasl.ChannelAuthenticationScheme
ChannelErrorResponseEvent - Class in alluxio.client.file.dora.netty.event
Transport error response event.
ChannelErrorResponseEvent(Throwable) - Constructor for class alluxio.client.file.dora.netty.event.ChannelErrorResponseEvent
Channel error response event.
ChannelIdInjector - Class in alluxio.security.authentication
Client side interceptor that is used to augment outgoing metadata with the unique id for the channel that the RPC is being called on.
ChannelIdInjector(UUID) - Constructor for class alluxio.security.authentication.ChannelIdInjector
Creates the injector that augments the outgoing metadata with given Id.
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.AbstractReadHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.HeartbeatHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.UnsupportedMessageHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.worker.s3.S3HttpHandler
 
channelRead0(ChannelHandlerContext, HttpObject) - Method in class alluxio.worker.http.HttpServerHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class alluxio.worker.http.HttpServerHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class alluxio.worker.s3.S3HttpHandler
 
CHANNELREF_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
 
channelRegistered(ChannelHandlerContext) - Method in class alluxio.worker.netty.AbstractReadHandler
 
channelType(Class<? extends ServerChannel>) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the netty channel type.
ChannelType - Enum in alluxio.network
What type of netty channel to use.
channelUnregistered(ChannelHandlerContext) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class alluxio.worker.netty.AbstractReadHandler
 
check() - Method in class alluxio.cli.fs.command.job.JobAttempt
Returns the status of the job attempt.
check(Clients) - Method in class alluxio.master.backcompat.FsTestOp
 
check(FileSystem) - Method in class alluxio.master.backcompat.FsTestOp
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.AsyncPersist
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateDirectory
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateFile
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.Delete
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.Mount
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.PersistDirectory
 
check(Clients) - Method in class alluxio.master.backcompat.ops.PersistFile
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.Rename
 
check(FileSystem) - Method in class alluxio.master.backcompat.ops.SetAcl
 
check(Clients) - Method in class alluxio.master.backcompat.ops.UpdateUfsMode
 
check(Clients) - Method in interface alluxio.master.backcompat.TestOp
Verifies the result of the test operation.
CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyJobPOptions
 
CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveJobPOptions
 
CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteOptions
 
CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
CHECK_CONTENT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
CHECK_FILE_EXISTS - Static variable in class alluxio.conf.PropertyKey
 
checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
checkAccess(AlluxioURI, CheckAccessPOptions) - Method in interface alluxio.client.file.FileSystem
Checks access to a path.
checkAccess(AlluxioURI, CheckAccessPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Check access to a path.
checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
checkAccess(AlluxioURI, CheckAccessPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Checks access to path.
checkAccess(CheckAccessPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Checks access to path.
checkAccess(CheckAccessPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Checks access to path.
checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Checks access to path.
checkAccess(AlluxioURI, CheckAccessContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
checkAccess(AlluxioURI, CheckAccessContext) - Method in interface alluxio.master.file.FileSystemMaster
Checks access to path.
checkAccess(CheckAccessPRequest, StreamObserver<CheckAccessPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
CheckAccessContext - Class in alluxio.master.file.contexts
Used to merge and wrap CheckAccessPOptions.
checkAccessDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
CheckAccessPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckAccessPOptions
CheckAccessPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckAccessPOptions
CheckAccessPOptionsOrBuilder - Interface in alluxio.grpc
 
CheckAccessPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckAccessPRequest
CheckAccessPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckAccessPRequest
CheckAccessPRequestOrBuilder - Interface in alluxio.grpc
 
CheckAccessPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckAccessPResponse
CheckAccessPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckAccessPResponse
CheckAccessPResponseOrBuilder - Interface in alluxio.grpc
 
checkAndAcquireSharedLock() - Method in class alluxio.rocks.RocksStore
This is the core logic of the shared lock mechanism.
CheckCachedCommand - Class in alluxio.cli.fs.command
Moves a file or a directory in the Alluxio filesystem using job service.
CheckCachedCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CheckCachedCommand
 
CheckCluster - Class in alluxio.cli
In this test, we cover all workers by performing the following steps: 1.
checkConflicts() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
 
checkConsistency(AlluxioURI, CheckConsistencyPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Checks the consistency of Alluxio metadata against the under storage for all files and directories in a given subtree.
checkConsistency(AlluxioURI, CheckConsistencyPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
checkConsistency(CheckConsistencyPRequest, StreamObserver<CheckConsistencyPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Checks the consistency of the files and directores with the path as the root of the subtree
checkConsistency(CheckConsistencyPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Checks the consistency of the files and directores with the path as the root of the subtree
checkConsistency(CheckConsistencyPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Checks the consistency of the files and directores with the path as the root of the subtree
checkConsistency(CheckConsistencyPRequest, StreamObserver<CheckConsistencyPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Checks the consistency of the files and directores with the path as the root of the subtree
checkConsistency(AlluxioURI, CheckConsistencyContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
checkConsistency(AlluxioURI, CheckConsistencyContext) - Method in interface alluxio.master.file.FileSystemMaster
Checks the consistency of the files and directories in the subtree under the path.
checkConsistency(CheckConsistencyPRequest, StreamObserver<CheckConsistencyPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
CheckConsistencyContext - Class in alluxio.master.file.contexts
Used to merge and wrap CheckConsistencyPOptions.
checkConsistencyDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
CheckConsistencyPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckConsistencyPOptions
CheckConsistencyPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckConsistencyPOptions
CheckConsistencyPOptionsOrBuilder - Interface in alluxio.grpc
 
CheckConsistencyPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckConsistencyPRequest
CheckConsistencyPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckConsistencyPRequest
CheckConsistencyPRequestOrBuilder - Interface in alluxio.grpc
 
CheckConsistencyPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckConsistencyPResponse
CheckConsistencyPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CheckConsistencyPResponse
CheckConsistencyPResponseOrBuilder - Interface in alluxio.grpc
 
checkCopyPermission(String, String) - Method in class alluxio.worker.dora.PagedDoraWorker
 
checkDirectory(InodeDirectory, AlluxioURI) - Method in class alluxio.master.file.UfsSyncChecker
Check if immediate children of directory are in sync with UFS.
checkExistsForPath(String) - Method in class alluxio.membership.AlluxioEtcdClient
Check existence of a single given path.
checkFileLocation(String, GetStatusPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Get a map that maps file path to the workers list.
checkFileLocation(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
Check the location of the specified path.
checkFileLocation(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
Check the location of the specified path.
checkIfComplete(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
On any exception, check with Master on if the there's an object file.
checkIfComplete(String) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
On any exception, check with Master on if the there's an object file.
checkInodeList(String, List<String>, Mode.Bits, String, List<InodeView>, boolean) - Method in class alluxio.master.file.DefaultPermissionChecker
This method provides basic permission checking logic on a list of inodes.
checkJobStatus() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Returns the status of the job.
checkMasterClientService(AlluxioConfiguration) - Static method in class alluxio.cli.fsadmin.FileSystemAdminShellUtils
Checks if the master client service is available.
checkMinimalPollingPeriod(TimeUnit, int) - Static method in class alluxio.metrics.MetricsSystem
Checks if the poll period is smaller that the minimal poll period which is 1 second.
checkMovePermission(String, String) - Method in class alluxio.worker.dora.PagedDoraWorker
 
checkNameLength(AlluxioURI) - Static method in class alluxio.fuse.AlluxioFuseUtils
Checks the input file length.
checkNameservice() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
 
checkNumOfArgsEquals(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments equals n for command.
checkNumOfArgsNoLessThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments is no less than n for command.
checkNumOfArgsNoMoreThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments is no more than n for command.
checkParentPermission(Mode.Bits, LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
 
checkParentPermission(Mode.Bits, LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
Checks whether a user has permission to perform a specific action on the parent of the given path; if parent directory does not exist, treats the closest ancestor directory of the path as its parent and checks permission on it.
checkPathIsAlluxioDirectory(FileSystem, String, S3AuditContext) - Static method in class alluxio.proxy.s3.S3RestUtils
Check if a path in alluxio is a directory.
checkPathIsAlluxioDirectory(FileSystem, String, S3AuditContext, Cache<String, Boolean>) - Static method in class alluxio.proxy.s3.S3RestUtils
Check if a path in alluxio is a directory.
checkPathIsAlluxioDirectory(FileSystem, String, S3AuditContext) - Static method in class alluxio.worker.s3.S3NettyHandler
Check if a path in alluxio is a directory.
checkPermission(Mode.Bits, LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
 
checkPermission(String, List<String>, AclAction) - Method in class alluxio.master.file.meta.Inode
 
checkPermission(String, List<String>, AclAction) - Method in interface alluxio.master.file.meta.InodeView
Checks whether the user or one of the groups has the permission to take the action.
checkPermission(String, List<String>, AclAction) - Method in class alluxio.master.file.meta.MutableInode
 
checkPermission(Mode.Bits, LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
Checks whether a user has permission to perform a specific action on a path.
checkPermission(String, List<String>, AclAction) - Method in class alluxio.security.authorization.AccessControlList
Checks whether the user has the permission to perform the action.
checkpoint() - Method in interface alluxio.client.meta.MetaMasterClient
Creates a checkpoint in the primary master journal system.
checkpoint() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
checkpoint(CheckpointPOptions, StreamObserver<CheckpointPResponse>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
Creates a checkpoint in the primary master journal system.
checkpoint(CheckpointPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
Creates a checkpoint in the primary master journal system.
checkpoint(CheckpointPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
Creates a checkpoint in the primary master journal system.
checkpoint(CheckpointPOptions, StreamObserver<CheckpointPResponse>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
Creates a checkpoint in the primary master journal system.
checkpoint(StateLockManager) - Method in interface alluxio.master.journal.JournalSystem
Creates a checkpoint in the primary master journal system.
checkpoint(StateLockManager) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
checkpoint(StateLockManager) - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
checkpoint() - Method in class alluxio.master.journal.ufs.UfsJournal
Creates a checkpoint in this ufs journal.
checkpoint(StateLockManager) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
checkpoint() - Method in class alluxio.master.meta.DefaultMetaMaster
 
checkpoint() - Method in interface alluxio.master.meta.MetaMaster
Creates a checkpoint in the primary master journal system.
checkpoint(CheckpointPOptions, StreamObserver<CheckpointPResponse>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
CHECKPOINT - Static variable in class alluxio.multi.process.PortCoordination
 
CheckpointCommand - Class in alluxio.cli.fsadmin.journal
Command for triggering a checkpoint in the primary master journal system.
CheckpointCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.journal.CheckpointCommand
 
Checkpointed - Interface in alluxio.master.journal.checkpoint
Base class for Alluxio classes which can be written to and read from metadata checkpoints.
CheckpointedIdHashSet - Class in alluxio.master.file.meta
A concurrent hash set of Long values that supports writing to and restoring from checkpoints.
CheckpointedIdHashSet() - Constructor for class alluxio.master.file.meta.CheckpointedIdHashSet
Constructs a new checkpointed id hash set.
CheckpointFormat - Interface in alluxio.master.journal.checkpoint
Interface for checkpoint formats.
CheckpointFormat.CheckpointReader - Interface in alluxio.master.journal.checkpoint
Interface for checkpoint readers.
CheckpointInputStream - Class in alluxio.master.journal.checkpoint
Input stream for reading checkpoints.
CheckpointInputStream(InputStream) - Constructor for class alluxio.master.journal.checkpoint.CheckpointInputStream
 
CheckpointName - Enum in alluxio.master.journal.checkpoint
Names for associating checkpoint data with the classes they represent.
CheckpointOutputStream - Class in alluxio.master.journal.checkpoint
Output stream for writing checkpoints.
CheckpointOutputStream(OutputStream, CheckpointType) - Constructor for class alluxio.master.journal.checkpoint.CheckpointOutputStream
 
CheckpointPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.CheckpointPOptions
CheckpointPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.CheckpointPOptions
CheckpointPOptionsOrBuilder - Interface in alluxio.grpc
 
CheckpointPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.CheckpointPResponse
CheckpointPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.CheckpointPResponse
CheckpointPResponseOrBuilder - Interface in alluxio.grpc
 
CheckpointType - Enum in alluxio.master.journal.checkpoint
Enumeration of different checkpoint types used by the master.
checkRatio(AlluxioConfiguration, PropertyKey) - Static method in class alluxio.util.ConfigurationUtils
Checks that the given property key is a ratio from 0.0 and 1.0, throwing an exception if it is not.
CheckRequest - Class in alluxio.grpc
The check request
CheckRequest.Builder - Class in alluxio.grpc
The check request
CheckRequestOrBuilder - Interface in alluxio.grpc
 
CheckResponse - Class in alluxio.grpc
The check response
CheckResponse.Builder - Class in alluxio.grpc
The check response
CheckResponseOrBuilder - Interface in alluxio.grpc
 
CHECKS3BUCKETPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
CHECKS3BUCKETPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
checkSetAttributePermission(LockedInodePath, boolean, boolean, boolean) - Method in class alluxio.master.file.DefaultPermissionChecker
 
checkSetAttributePermission(LockedInodePath, boolean, boolean, boolean) - Method in interface alluxio.master.file.PermissionChecker
Checks whether a user has permission to edit the attribute of a given path.
checkSetTableConfig(PropertyKey, PropertyKey, PropertyKey, PropertyKey, List<RocksObject>) - Static method in class alluxio.rocks.RocksStore
loads RockDB configuration options based on property key configurations.
checkStatusesForUploadId(FileSystem, FileSystem, AlluxioURI, String) - Static method in class alluxio.proxy.s3.S3RestUtils
Fetches and returns the corresponding URIStatus for both the multipart upload temp directory and the Alluxio S3 metadata file.
CHECKSUM_COMBINE_MODE - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
ChecksumCommand - Class in alluxio.cli.fs.command
Calculates the MD5 checksum for a file.
ChecksumCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChecksumCommand
 
ChecksumType - Enum in alluxio.underfs
UFS checksum type.
checkSuperUser() - Method in class alluxio.master.file.DefaultPermissionChecker
 
checkSuperUser() - Method in interface alluxio.master.file.PermissionChecker
Checks whether the user is a super user or in super group.
checkSupported(AuthType) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
Used to check if given authentication is supported by the server.
CHECKUFS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMountTablePRequest
 
checkUnderWritableMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Checks to see if a write operation is allowed for the specified Alluxio path, by determining if it is under a readonly mount point.
checkVersion(long) - Method in class alluxio.AbstractClient
Checks that the service version is compatible with the client.
ChgrpCommand - Class in alluxio.cli.fs.command
Changes the group of a file or directory specified by args.
ChgrpCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChgrpCommand
Creates a new instance of ChgrpCommand.
CHILD_COUNT_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
CHILDREN_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
chmod(String, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
chmod(String, long) - Method in class alluxio.fuse.StackFS
 
chmod(String, long) - Method in interface alluxio.jnifuse.FuseFileSystem
 
chmodCallback(String, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
ChmodCommand - Class in alluxio.cli.fs.command
Changes the permission of a file or directory specified by args.
ChmodCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChmodCommand
Creates a new instance of ChmodCommand.
choosePreferredWorker(List<BlockWorkerInfo>) - Method in class alluxio.client.file.dora.DoraCacheClient
Chooses a client preferred worker from multiple workers which hold multiple replicas.
chown(String, long, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
chown(String, long, long) - Method in class alluxio.fuse.StackFS
 
chown(String, long, long) - Method in interface alluxio.jnifuse.FuseFileSystem
 
chownCallback(String, long, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
ChownCommand - Class in alluxio.cli.fs.command
Changes the owner of a file or directory specified by args.
ChownCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ChownCommand
Creates a new instance of ChownCommand.
Chunk - Class in alluxio.grpc
The data chunk.
Chunk.Builder - Class in alluxio.grpc
The data chunk.
CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadResponse
 
CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
 
CHUNK_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequest
 
CHUNK_SIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
CHUNK_SIZE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
ChunkedEncodingInputStream - Class in alluxio.s3
This input stream decodes an aws-chunked encoded input stream into its original form.
ChunkedEncodingInputStream(InputStream) - Constructor for class alluxio.s3.ChunkedEncodingInputStream
Creates a FilterInputStream by assigning the argument in to the field this.in so as to remember it for later use.
ChunkOrBuilder - Interface in alluxio.grpc
 
chunkSize() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
 
chunkSize() - Method in interface alluxio.client.block.stream.DataWriter
 
chunkSize() - Method in class alluxio.client.block.stream.GrpcDataWriter
 
chunkSize() - Method in class alluxio.client.block.stream.NettyDataWriter
 
chunkSize() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
CLASS_NAME_FIELD - Static variable in interface alluxio.util.JsonSerializable
This must match the java field for the class name.
classBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
CLEAN_CHECK_DATA - Static variable in class alluxio.cli.fs.command.ConsistentHashCommand
 
cleanCheckData() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
Clean all the check data.
cleanDirectBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Forces to unmap a direct buffer if this buffer is no longer used.
cleanPath(String) - Static method in class alluxio.util.io.PathUtils
Checks and normalizes the given path.
cleanup() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
cleanup(Collection<Long>) - Method in class alluxio.master.job.workflow.WorkflowTracker
Recursively cleanup the parent workflows given plans to be removed from the PlanTracker.
cleanup() - Method in class alluxio.stress.cli.Benchmark
Perform post-run cleanups.
cleanup() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
cleanup() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
cleanup() - Method in interface alluxio.underfs.UnderFileSystem
Cleans up the under file system.
cleanup() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
cleanupOldSnapshots(SnapshotRetentionPolicy) - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
cleanupRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
cleanupRequest(BlockWriteRequestContext) - Method in class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
 
cleanupRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
cleanupSession(long) - Method in class alluxio.worker.dora.PagedDoraWorker
 
cleanupSession(long) - Method in interface alluxio.worker.SessionCleanable
Cleans up the session.
cleanupSessionTempBlocks(long, List<Long>) - Method in interface alluxio.worker.block.meta.StorageDir
Cleans up the temp block metadata for each block id passed in.
cleanupStaleJob() - Method in class alluxio.master.scheduler.Scheduler
Removes all finished jobs outside the retention time.
cleanupTempPath(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
Cleanup the temp object file for complete multipart upload.
cleanupTempPath(String) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
Cleanup the temp object file for complete multipart upload.
cleanupUfs() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
cleanupUfs() - Method in interface alluxio.master.file.FileSystemMaster
Periodically clean up the under file systems.
clear(Path) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
Clear the dir.
clear(int) - Method in interface alluxio.collections.BitSet
Sets the bit specified by the index to false.
clear(int) - Method in class alluxio.collections.BuiltinBitSet
 
clear() - Method in class alluxio.collections.ConcurrentHashSet
 
clear() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
clear() - Method in class alluxio.collections.DelegatingSet
 
clear() - Method in interface alluxio.collections.FieldIndex
Removes all the entries in this index.
clear() - Method in class alluxio.collections.IndexedSet
Removes all the entries in this set.
clear() - Method in class alluxio.collections.NonUniqueFieldIndex
 
clear() - Method in class alluxio.collections.UniqueFieldIndex
 
clear() - Method in class alluxio.collections.UnmodifiableArrayList
 
clear() - Method in class alluxio.conf.AlluxioProperties
Clears all existing user-specified properties.
clear() - Method in class alluxio.grpc.ActionInfo.Builder
 
clear() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
clear() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
clear() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
clear() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
clear() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
clear() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
clear() - Method in class alluxio.grpc.BackupPOptions.Builder
 
clear() - Method in class alluxio.grpc.BackupPRequest.Builder
 
clear() - Method in class alluxio.grpc.BackupPStatus.Builder
 
clear() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.Block.Builder
 
clear() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
clear() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
clear() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
clear() - Method in class alluxio.grpc.BlockIdList.Builder
 
clear() - Method in class alluxio.grpc.BlockInfo.Builder
 
clear() - Method in class alluxio.grpc.BlockLocation.Builder
 
clear() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
clear() - Method in class alluxio.grpc.BlockStatus.Builder
 
clear() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
clear() - Method in class alluxio.grpc.BuildVersion.Builder
 
clear() - Method in class alluxio.grpc.CacheRequest.Builder
 
clear() - Method in class alluxio.grpc.CacheResponse.Builder
 
clear() - Method in class alluxio.grpc.CancelPOptions.Builder
 
clear() - Method in class alluxio.grpc.CancelPRequest.Builder
 
clear() - Method in class alluxio.grpc.CancelPResponse.Builder
 
clear() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
clear() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
clear() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
clear() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
clear() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
clear() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
clear() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
clear() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
clear() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
clear() - Method in class alluxio.grpc.CheckRequest.Builder
 
clear() - Method in class alluxio.grpc.CheckResponse.Builder
 
clear() - Method in class alluxio.grpc.Chunk.Builder
 
clear() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
clear() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
clear() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
clear() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
clear() - Method in class alluxio.grpc.ClientMetrics.Builder
 
clear() - Method in class alluxio.grpc.CmdProgress.Builder
 
clear() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
clear() - Method in class alluxio.grpc.CmdSummary.Builder
 
clear() - Method in class alluxio.grpc.Command.Builder
 
clear() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
clear() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
clear() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
clear() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
clear() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
clear() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
clear() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
clear() - Method in class alluxio.grpc.ConfigProperties.Builder
 
clear() - Method in class alluxio.grpc.ConfigProperty.Builder
 
clear() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
clear() - Method in class alluxio.grpc.CopyRequest.Builder
 
clear() - Method in class alluxio.grpc.CopyResponse.Builder
 
clear() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
clear() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
clear() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
clear() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
clear() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
clear() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
clear() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
clear() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
clear() - Method in class alluxio.grpc.DeletePOptions.Builder
 
clear() - Method in class alluxio.grpc.DeletePRequest.Builder
 
clear() - Method in class alluxio.grpc.DeletePResponse.Builder
 
clear() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.ErrorInfo.Builder
 
clear() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
clear() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
clear() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
clear() - Method in class alluxio.grpc.File.Builder
 
clear() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
clear() - Method in class alluxio.grpc.FileFailure.Builder
 
clear() - Method in class alluxio.grpc.FileInfo.Builder
 
clear() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
clear() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
clear() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
clear() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
clear() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
clear() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
clear() - Method in class alluxio.grpc.FreePOptions.Builder
 
clear() - Method in class alluxio.grpc.FreePRequest.Builder
 
clear() - Method in class alluxio.grpc.FreePResponse.Builder
 
clear() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
clear() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
clear() - Method in class alluxio.grpc.FsOpPId.Builder
 
clear() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
clear() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
clear() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
clear() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
clear() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
clear() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
clear() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
clear() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
clear() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
clear() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
clear() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
clear() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
clear() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
clear() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
clear() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
clear() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
clear() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
clear() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
clear() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
clear() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
clear() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
clear() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
clear() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
clear() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
clear() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
clear() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
clear() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
clear() - Method in class alluxio.grpc.JobCommand.Builder
 
clear() - Method in class alluxio.grpc.JobDescription.Builder
 
clear() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
clear() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
clear() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
clear() - Method in class alluxio.grpc.JobInfo.Builder
 
clear() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
clear() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
clear() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
clear() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
clear() - Method in class alluxio.grpc.JobProgress.Builder
 
clear() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
clear() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
clear() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
clear() - Method in class alluxio.grpc.JobUnused.Builder
 
clear() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
clear() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
clear() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
clear() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
clear() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
clear() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
clear() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
clear() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
clear() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
clear() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
clear() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
clear() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
clear() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
clear() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
clear() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
clear() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
clear() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
clear() - Method in class alluxio.grpc.LoadRequest.Builder
 
clear() - Method in class alluxio.grpc.LoadResponse.Builder
 
clear() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
clear() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
clear() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
clear() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
clear() - Method in class alluxio.grpc.MasterInfo.Builder
 
clear() - Method in class alluxio.grpc.MasterVersion.Builder
 
clear() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
clear() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
clear() - Method in class alluxio.grpc.Metric.Builder
 
clear() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
clear() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
clear() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
clear() - Method in class alluxio.grpc.MetricValue.Builder
 
clear() - Method in class alluxio.grpc.MountPointInfo.Builder
 
clear() - Method in class alluxio.grpc.MountPOptions.Builder
 
clear() - Method in class alluxio.grpc.MountPRequest.Builder
 
clear() - Method in class alluxio.grpc.MountPResponse.Builder
 
clear() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
clear() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
clear() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
clear() - Method in class alluxio.grpc.MoveRequest.Builder
 
clear() - Method in class alluxio.grpc.MoveResponse.Builder
 
clear() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
clear() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
clear() - Method in class alluxio.grpc.NetAddress.Builder
 
clear() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
clear() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
clear() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
clear() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clear() - Method in class alluxio.grpc.PAcl.Builder
 
clear() - Method in class alluxio.grpc.PAclEntry.Builder
 
clear() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
clear() - Method in class alluxio.grpc.PersistFile.Builder
 
clear() - Method in class alluxio.grpc.PMode.Builder
 
clear() - Method in class alluxio.grpc.PolicyInfo.Builder
 
clear() - Method in class alluxio.grpc.PolicyStatus.Builder
 
clear() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
clear() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
clear() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
clear() - Method in class alluxio.grpc.ProxyStatus.Builder
 
clear() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
clear() - Method in class alluxio.grpc.ReadRequest.Builder
 
clear() - Method in class alluxio.grpc.ReadResponse.Builder
 
clear() - Method in class alluxio.grpc.RegisterCommand.Builder
 
clear() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
clear() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
clear() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
clear() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
clear() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
clear() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
clear() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
clear() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
clear() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
clear() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
clear() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clear() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
clear() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
clear() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
clear() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
clear() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
clear() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
clear() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
clear() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
clear() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
clear() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
clear() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
clear() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
clear() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
clear() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
clear() - Method in class alluxio.grpc.RenamePOptions.Builder
 
clear() - Method in class alluxio.grpc.RenamePRequest.Builder
 
clear() - Method in class alluxio.grpc.RenamePResponse.Builder
 
clear() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
clear() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
clear() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
clear() - Method in class alluxio.grpc.RetryInfo.Builder
 
clear() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
clear() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
clear() - Method in class alluxio.grpc.Route.Builder
 
clear() - Method in class alluxio.grpc.RouteFailure.Builder
 
clear() - Method in class alluxio.grpc.RunPOptions.Builder
 
clear() - Method in class alluxio.grpc.RunPRequest.Builder
 
clear() - Method in class alluxio.grpc.RunPResponse.Builder
 
clear() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
clear() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
clear() - Method in class alluxio.grpc.SaslMessage.Builder
 
clear() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
clear() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
clear() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
clear() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
clear() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
clear() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
clear() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
clear() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
clear() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
clear() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
clear() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
clear() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
clear() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
clear() - Method in class alluxio.grpc.SnapshotData.Builder
 
clear() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
clear() - Method in class alluxio.grpc.StatusSummary.Builder
 
clear() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
clear() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
clear() - Method in class alluxio.grpc.StorageList.Builder
 
clear() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
clear() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
clear() - Method in class alluxio.grpc.SubmitOptions.Builder
 
clear() - Method in class alluxio.grpc.SubmitRequest.Builder
 
clear() - Method in class alluxio.grpc.SubmitResponse.Builder
 
clear() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
clear() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
clear() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
clear() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
clear() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
clear() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
clear() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
clear() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
clear() - Method in class alluxio.grpc.table.Constraint.Builder
 
clear() - Method in class alluxio.grpc.table.Database.Builder
 
clear() - Method in class alluxio.grpc.table.Date.Builder
 
clear() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
clear() - Method in class alluxio.grpc.table.Decimal.Builder
 
clear() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
clear() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
clear() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
clear() - Method in class alluxio.grpc.table.Domain.Builder
 
clear() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
clear() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
clear() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
clear() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
clear() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
clear() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
clear() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
clear() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
clear() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
clear() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
clear() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
clear() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
clear() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
clear() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
clear() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
clear() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
clear() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
clear() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
clear() - Method in class alluxio.grpc.table.Layout.Builder
 
clear() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
clear() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
clear() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
clear() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
clear() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
clear() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
clear() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
clear() - Method in class alluxio.grpc.table.Partition.Builder
 
clear() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
clear() - Method in class alluxio.grpc.table.Range.Builder
 
clear() - Method in class alluxio.grpc.table.RangeSet.Builder
 
clear() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
clear() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
clear() - Method in class alluxio.grpc.table.Schema.Builder
 
clear() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
clear() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
clear() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
clear() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
clear() - Method in class alluxio.grpc.table.TableInfo.Builder
 
clear() - Method in class alluxio.grpc.table.Transformation.Builder
 
clear() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
clear() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
clear() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
clear() - Method in class alluxio.grpc.table.Value.Builder
 
clear() - Method in class alluxio.grpc.TierList.Builder
 
clear() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
clear() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
clear() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
clear() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
clear() - Method in class alluxio.grpc.TransportMessage.Builder
 
clear() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
clear() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
clear() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
clear() - Method in class alluxio.grpc.UfsInfo.Builder
 
clear() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
clear() - Method in class alluxio.grpc.UfsStatus.Builder
 
clear() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
clear() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
clear() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
clear() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
clear() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
clear() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
clear() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
clear() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
clear() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
clear() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
clear() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
clear() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
clear() - Method in class alluxio.grpc.WorkerInfo.Builder
 
clear() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
clear() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
clear() - Method in class alluxio.grpc.WriteOptions.Builder
 
clear() - Method in class alluxio.grpc.WriteRequest.Builder
 
clear() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
clear() - Method in class alluxio.grpc.WriteResponse.Builder
 
clear() - Method in class alluxio.master.file.FileSystemJournalEntryMerger
 
clear() - Method in interface alluxio.master.journal.JournalEntryMerger
Clears the existing journal entries.
clear() - Method in interface alluxio.master.metastore.BlockMetaStore
Removes all metadata from the block store.
clear() - Method in class alluxio.master.metastore.caching.Cache
Clears all entries from the map.
clear() - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
clear() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
clear() - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
clear() - Method in interface alluxio.master.metastore.InodeStore
Removes all inodes and edges.
clear() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
clear() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
clear() - Method in class alluxio.master.metrics.MetricsStore
Clears all the metrics.
clear() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
clear() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
clear() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
clear() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
clear() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
clear() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
clear() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
clear() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
clear() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
clear() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
clear() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
clear() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
clear() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
clear() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
clear() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
clear() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
clear() - Method in class alluxio.rocks.RocksStore
Clears and re-initializes the database.
clear() - Method in class alluxio.s3.TaggingData
Removes all tags contained in this object.
clear() - Method in interface alluxio.worker.dora.DoraMetaStore
Removes all metadata from the dora meta store.
clear() - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
Clears all the metadata in this RocksDB.
clearAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
clearAccessMode() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.Bits accessMode = 3;
clearAcl() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
clearAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
clearAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
clearAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
clearAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
clearAction() - Method in class alluxio.grpc.SetAclPRequest.Builder
the set action to perform
clearAction() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional .alluxio.proto.journal.PSetAclAction action = 3;
clearActionId() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionId = 1;
clearActionId() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string actionId = 2;
clearActions() - Method in class alluxio.grpc.PAclEntry.Builder
repeated .alluxio.grpc.file.PAclAction actions = 3;
clearActions() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
repeated .alluxio.proto.shared.AclAction actions = 1;
clearActions() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
repeated .alluxio.proto.shared.AclAction actions = 3;
clearActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
clearActionsCanceled() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsCanceled = 8;
clearActionsFailed() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsFailed = 9;
clearActionsRunning() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsRunning = 6;
clearActionsScheduled() - Method in class alluxio.grpc.PolicyStatus.Builder
metrics
clearActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsSucceeded = 7;
clearActionStatus() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionStatus = 3;
clearActionType() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionType = 2;
clearActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
clearAddedBlocks() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
clearAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
clearAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
clearAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
clearAddress() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
clearAddress() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
clearAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
clearAddresses() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
clearAddresses() - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
clearAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
clearAffectedPaths() - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
clearAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
optional bool all = 1;
clearAllMetrics() - Static method in class alluxio.metrics.MetricsSystem
Resets the metric registry and removes all the metrics.
clearAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
clearAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional bool allowed = 2;
clearAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
optional bool allowedOnStandbyMasters = 2;
clearAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool allowExists = 2;
clearAllowLeader() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool allowLeader = 3;
clearAllThroughput() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
Clears all data points from the result.
clearAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool alluxioOnly = 2;
clearAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, this field is about whether to delete in the UFS.
clearAlluxioPath() - Method in class alluxio.grpc.File.Builder
optional string alluxio_path = 1;
clearAlluxioPath() - Method in class alluxio.grpc.MountPRequest.Builder
the path of alluxio mount point
clearAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
optional string alluxioPath = 1;
clearAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest.Builder
the path of the alluxio mount point
clearAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
the path of alluxio mount point
clearAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
clearAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
clearAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional string alluxioVersion = 3;
clearAsync() - Method in class alluxio.grpc.CacheRequest.Builder
optional bool async = 6;
clearAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
clearAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
clearAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
clearAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional double avg_col_len = 2;
clearAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional double avg_col_len = 2;
clearBackupError() - Method in class alluxio.grpc.BackupPStatus.Builder
optional bytes backupError = 6;
clearBackupHost() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupHost = 3;
clearBackupId() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupId = 1;
clearBackupId() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
optional string backupId = 1;
clearBackupState() - Method in class alluxio.grpc.BackupPStatus.Builder
optional .alluxio.grpc.meta.BackupState backupState = 2;
clearBackupUri() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupUri = 4;
clearBandwidth() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional int64 bandwidth = 1;
clearBandwidth() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional int64 bandwidth = 1;
clearBandwidth() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional int64 bandwidth = 1;
clearBandwidth() - Method in class alluxio.grpc.UfsReadOptions.Builder
optional int64 bandwidth = 3;
clearBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 bandwidth = 4;
clearBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 bandwidth = 3;
clearBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 bandwidth = 4;
clearBaseLayout() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
clearBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Batch size for partial listings.
clearBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
clearBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.Bits bits = 1;
clearBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional string bit_vectors = 4;
clearBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional string bit_vectors = 4;
clearBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional string bit_vectors = 5;
clearBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional string bit_vectors = 5;
clearBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional string bit_vectors = 5;
clearBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional string bit_vectors = 5;
clearBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional string bit_vectors = 5;
clearBlock() - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
clearBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
clearBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
clearBlockId() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.grpc.Block.Builder
required int64 block_id = 1;
clearBlockId() - Method in class alluxio.grpc.BlockIdList.Builder
repeated int64 blockId = 1;
clearBlockId() - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 blockId = 1;
clearBlockId() - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the block being committed
clearBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
the id of the block
clearBlockId() - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
clearBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
clearBlockIds() - Method in class alluxio.grpc.FileInfo.Builder
repeated int64 blockIds = 13;
clearBlockIds() - Method in class alluxio.grpc.PersistFile.Builder
repeated int64 blockIds = 2;
clearBlockIds() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
clearBlockInfo() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
clearBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
clearBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
clearBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
clearBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
clearBlocks() - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
clearBlocks() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
clearBlocks() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated int64 blocks = 16;
clearBlockSize() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 block_size = 3;
clearBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The block size.
clearBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 blockSizeBytes = 1;
clearBlockSizeBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 blockSizeBytes = 6;
clearBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 block_size_bytes = 8;
clearBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 block_size_bytes = 2;
clearBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
file only
clearBlockStatus() - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
clearBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
clearBooleanType() - Method in class alluxio.grpc.table.Value.Builder
bool boolean_type = 4;
clearBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
optional int64 bucket_count = 2;
clearBucketedBy() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
clearBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
clearBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
clearBuildVersion() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
clearBypassDelegation() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool bypassDelegation = 4;
clearBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
optional int64 bytes = 1;
clearBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
optional int64 bytes = 1;
clearBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int64 bytes_skipped = 4;
clearCacheable() - Method in class alluxio.grpc.FileInfo.Builder
optional bool cacheable = 11;
clearCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool cacheable = 11;
clearCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool cacheable = 5;
clearCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 cacheSize = 2;
clearCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
clearCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, this request is to cancel the reading request for the id.
clearCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
clearCancelTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
clearCandidates() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
clearCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional bool canRegisterAgain = 3;
clearCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 capacityBytes = 1;
clearCapacityBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 capacityBytes = 5;
clearCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
clearCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
clearCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
 
clearChannelRef() - Method in class alluxio.grpc.SaslMessage.Builder
optional string channelRef = 5;
clearCheckContent() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool check_content = 6;
clearCheckContent() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool check_content = 6;
clearCheckContent() - Method in class alluxio.grpc.WriteOptions.Builder
optional bool check_content = 3;
clearCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool check_content = 11;
clearCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool check_content = 11;
clearCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool checkS3BucketPath = 8;
clearCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool checkS3BucketPath = 14;
clearCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
optional bool checkUfs = 1;
clearChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 child_count = 26;
clearChildren() - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
clearChunk() - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
clearChunk() - Method in class alluxio.grpc.SnapshotData.Builder
optional bytes chunk = 3;
clearChunk() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
clearChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 chunk_size = 5;
clearChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, the server should send packets in the specified packet size.
clearClientId() - Method in class alluxio.grpc.SaslMessage.Builder
optional string clientId = 3;
clearClientMetrics() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
clearClients() - Method in class alluxio.master.LocalAlluxioMaster
Clears all the clients.
clearClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string clusterConfigHash = 1;
clearClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string clusterConfigHash = 3;
clearClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 clusterConfigLastUpdateTime = 5;
clearClusterConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
clearClusterId() - Method in class alluxio.grpc.MasterInfo.Builder
optional string clusterId = 11;
clearClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
optional string cluster_id = 1;
clearClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
clearCmdConfig() - Method in class alluxio.grpc.SubmitRequest.Builder
optional bytes cmdConfig = 1;
clearCmdProgress() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
clearCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
optional .alluxio.grpc.job.Status cmdStatus = 1;
clearCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
clearCode() - Method in class alluxio.grpc.BlockStatus.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
clearCode() - Method in class alluxio.grpc.FileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
clearCode() - Method in class alluxio.grpc.LoadFileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
clearCode() - Method in class alluxio.grpc.RouteFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
clearColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_name = 1;
clearColNames() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
clearColNames() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
clearCols() - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
clearColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_type = 2;
clearColumn() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
clearColumnConstraints() - Method in class alluxio.grpc.table.Constraint.Builder
 
clearColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required string column_name = 1;
ClearCommand - Class in alluxio.cli.fsadmin.metrics
Clear the leading master (and workers) metrics.
ClearCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.metrics.ClearCommand
 
clearCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
clearCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
clearCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
clearCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
optional .alluxio.grpc.meta.MetaCommand command = 1;
clearCommand() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
clearCommandOptions() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
clearCommands() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
clearCommandType() - Method in class alluxio.grpc.Command.Builder
optional .alluxio.grpc.CommandType commandType = 1;
clearCommandType() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.CommandType commandType = 1;
clearComment() - Method in class alluxio.grpc.table.Database.Builder
optional string comment = 7;
clearComment() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string comment = 4;
clearCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
clearCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
clearCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
clearCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
clearCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
clearCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
clearCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
clearCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
clearCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
clearCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
clearCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
clearCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
clearCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
clearCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
clearCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
clearCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
clearCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
clearCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
clearCommonOptions() - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
clearCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
clearCompleted() - Method in class alluxio.grpc.FileInfo.Builder
optional bool completed = 8;
clearCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool completed = 10;
clearCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool completed = 4;
clearCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
clearConfigs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
clearConfigs() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
clearConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
clearContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string containerHost = 7;
clearContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
clearContentHash() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional string contentHash = 4;
clearContentHash() - Method in class alluxio.grpc.FileInfo.Builder
optional string contentHash = 34;
clearContentHash() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional string content_hash = 1;
clearContentHash() - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
clearContentLength() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 content_length = 2;
clearCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
clearCount() - Method in class alluxio.grpc.StatusSummary.Builder
optional int64 count = 2;
clearCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional bool createAncestors = 2;
clearCreatedAt() - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 created_at = 3;
clearCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 created_at = 3;
clearCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
clearCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
clearCreationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 creationTimeMs = 7;
clearCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 creation_time_ms = 6;
clearCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 creation_time_ms = 6;
clearCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 creation_time_ms = 6;
clearCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 creation_time_ms = 2;
clearCurrentBlocks() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
clearCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clearData() - Method in class alluxio.grpc.Chunk.Builder
optional bytes data = 1;
clearData() - Method in class alluxio.grpc.Command.Builder
repeated int64 data = 2;
clearData() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
clearData() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
clearData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
clearData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
clearDatabase() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
clearDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
optional string database = 1;
clearDataCols() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
clearDataPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 dataPort = 3;
clearDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
clearDaysSinceEpoch() - Method in class alluxio.grpc.table.Date.Builder
required int64 days_since_epoch = 1;
clearDb() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
clearDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string db_name = 4;
clearDbName() - Method in class alluxio.grpc.table.Database.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string db_name = 3;
clearDbName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string db_name = 1;
clearDbName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string db_name = 1;
clearDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
clearDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 decommissionedWorkerNum = 8;
clearDefaultAcl() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
clearDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
clearDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
clearDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
clearDefinition() - Method in class alluxio.grpc.table.Transformation.Builder
optional string definition = 2;
clearDefinition() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string definition = 3;
clearDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string definition = 3;
clearDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
clearDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
clearDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool deleteMountPoint = 6;
clearDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
clearDescription() - Method in class alluxio.grpc.JobInfo.Builder
optional string description = 13;
clearDescription() - Method in class alluxio.grpc.table.Database.Builder
optional string description = 2;
clearDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool directChildrenLoaded = 13;
clearDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
clearDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool direct_children_loaded = 3;
clearDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions.Builder
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
clearDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
optional .alluxio.grpc.journal.JournalDomain domain = 1;
clearDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string domainSocketPath = 5;
clearDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
clearDoubleType() - Method in class alluxio.grpc.table.Value.Builder
double double_type = 2;
clearDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
optional double doubleValue = 1;
clearDst() - Method in class alluxio.grpc.Route.Builder
required string dst = 2;
clearDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string dst = 2;
clearDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string dst = 2;
clearDstPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string dstPath = 3;
clearDstPath() - Method in class alluxio.grpc.RenamePRequest.Builder
the destination path
clearDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
Deprecated, use new_parent_id/new_name instead
clearDuration() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 duration = 6;
clearEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 end_time = 9;
clearEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 end_time = 8;
clearEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 end_time = 9;
clearEntries() - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
clearEntries() - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
clearEntries() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
clearEntries() - Method in class alluxio.security.authorization.AccessControlList
Clears out all entries (does not modify the owner name and owning group).
clearEntryCount() - Method in class alluxio.grpc.BackupPStatus.Builder
optional int64 entryCount = 5;
clearEof() - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
clearEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
clearEquatable() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
clearErrorMessage() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorMessage = 7;
clearErrorMessage() - Method in class alluxio.grpc.CmdSummary.Builder
optional string errorMessage = 7;
clearErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorMessage = 2;
clearErrorMsg() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorMsg = 5;
clearErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
clearErrors() - Method in class alluxio.grpc.PolicyStatus.Builder
 
clearErrorType() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorType = 6;
clearErrorType() - Method in class alluxio.grpc.ErrorInfo.Builder
optional .alluxio.grpc.ErrorType errorType = 1;
clearErrorType() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorType = 15;
clearErrorType() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorType = 6;
clearExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions.Builder
Mount info will be excluded from the list status response if this field is set to true.
clearExists() - Method in class alluxio.grpc.ExistsPResponse.Builder
optional bool exists = 1;
clearExists() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional bool exists = 3;
clearExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 expiryMs = 3;
clearFailures() - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
clearFailures() - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
clearFailures() - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ActionInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupPStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Block.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockIdList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockLocation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.BuildVersion.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CacheRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CacheResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CheckResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Chunk.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ClientMetrics.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CmdProgress.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CmdSummary.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Command.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ConfigProperties.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ConfigProperty.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CopyRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CopyResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DeletePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DeletePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DeletePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ErrorInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.File.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileFailure.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.FsOpPId.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobCommand.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobDescription.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobProgress.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobUnused.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LoadResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MasterVersion.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Metric.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MetricValue.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPointInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MountPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.MoveResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NetAddress.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PAcl.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PAclEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PersistFile.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PMode.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PolicyInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.PolicyStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ProxyStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReadRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReadResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterCommand.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RenamePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RenamePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RenamePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RetryInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.Route.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RouteFailure.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SaslMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SnapshotData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StatusSummary.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.StorageList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.SubmitResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Constraint.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Database.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Date.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Decimal.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Domain.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Layout.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Partition.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Range.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.RangeSet.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Schema.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TableInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Transformation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.table.Value.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TierList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UfsStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.grpc.WriteResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
clearFieldRanges() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
clearFile() - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
clearFileBlockInfos() - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
clearFileCount() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileCount = 2;
clearFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
The total number of files in the listing directory, (i.e.
clearFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string file_date_pattern = 6;
clearFileId() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 fileId = 1;
clearFileId() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
the id of the file
clearFileId() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
optional int64 fileId = 1;
clearFileId() - Method in class alluxio.grpc.PersistFile.Builder
optional int64 fileId = 1;
clearFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
clearFileInfo() - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
clearFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
clearFileInfo() - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
clearFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
clearFileInfos() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
clearFileInfos() - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
clearFilePath() - Method in class alluxio.grpc.ActionInfo.Builder
optional string filePath = 4;
clearFilePath() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string filePath = 3;
clearFilePath() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePath = 3;
clearFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePathFailed = 4;
clearFileSize() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileSize = 3;
clearFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int32 files_skipped = 3;
clearFilter() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string filter = 5;
clearFilter() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
clearFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
clearFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
clearFilters() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
clearFlush() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool flush = 5;
clearFolder() - Method in class alluxio.grpc.FileInfo.Builder
optional bool folder = 9;
clearForced() - Method in class alluxio.grpc.FreePOptions.Builder
optional bool forced = 2;
clearFormat() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
clearFormat() - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
clearFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 freeBytes = 3;
clearGroup() - Method in class alluxio.grpc.FileInfo.Builder
optional string group = 17;
clearGroup() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string group = 4;
clearGroup() - Method in class alluxio.grpc.UfsStatus.Builder
optional string group = 5;
clearGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
clearGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
clearGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
clearGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
clearGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string group = 10;
clearGroupActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
clearGroupBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits groupBits = 2;
clearHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool has_direct_children_loaded = 13;
clearHigh() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
clearHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
clearHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
clearHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double high_value = 2;
clearHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 high_value = 2;
clearHost() - Method in class alluxio.grpc.NetAddress.Builder
optional string host = 1;
clearHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string host = 1;
clearHostname() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional string hostname = 4;
clearId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional uint32 id = 1;
clearId() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.grpc.WriteRequestCommand.Builder
The block ID or UFS file ID.
clearId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
The block ID or UFS file ID.
clearId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 id = 2;
clearId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 id = 1;
clearId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 id = 1;
clearIdentifier() - Method in class alluxio.grpc.WorkerIdentity.Builder
exactly how this byte sequence is interpreted depends on the version of its definition
clearIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignoreClusterConf = 2;
clearIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignorePathConf = 3;
clearIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional bool ignore_sync_errors = 6;
clearInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inAlluxioPercentage = 24;
clearIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool includeRealContentHash = 5;
clearInconsistentPaths() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
clearInfo() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
clearInfos() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
clearInMemoryPercentage() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inMemoryPercentage = 25;
clearInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
clearInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
clearInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
clearInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
clearInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string input_format = 2;
clearInstance() - Method in class alluxio.grpc.Metric.Builder
optional string instance = 1;
clearIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool isAtomicWrite = 16;
clearIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_cacheable = 17;
clearIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_completed = 18;
clearIsDefault() - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefault = 5;
clearIsDefault() - Method in class alluxio.grpc.PAclEntry.Builder
optional bool isDefault = 4;
clearIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isDefault = 7;
clearIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional bool isDefault = 4;
clearIsDefaultEmpty() - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefaultEmpty = 6;
clearIsDirectory() - Method in class alluxio.grpc.UfsStatus.Builder
optional bool is_directory = 2;
clearIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_directory = 3;
clearIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isEmpty = 8;
clearIsLeader() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional bool isLeader = 3;
clearIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
directory only
clearIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool isMultipartUpload = 2;
clearIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_pinned = 9;
clearIsRetryable() - Method in class alluxio.grpc.RetryInfo.Builder
optional bool isRetryable = 1;
clearIsScanning() - Method in class alluxio.grpc.PolicyStatus.Builder
optional bool isScanning = 11;
clearIsSkip() - Method in class alluxio.grpc.RouteFailure.Builder
optional bool is_skip = 5;
clearIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional bool isThrowable = 2;
clearIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
True if the partial listing was truncated.
clearJobConfig() - Method in class alluxio.grpc.RunPRequest.Builder
optional bytes jobConfig = 1;
clearJobConfig() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes jobConfig = 3;
clearJobControlId() - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional int64 jobControlId = 1;
clearJobControlId() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 jobControlId = 1;
clearJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional int64 jobControlId = 1;
clearJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional int64 jobControlId = 1;
clearJobControlId() - Method in class alluxio.grpc.SubmitResponse.Builder
optional int64 jobControlId = 1;
clearJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
clearJobDescription() - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
clearJobError() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string job_error = 6;
clearJobId() - Method in class alluxio.grpc.CancelPRequest.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.RunPResponse.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 jobId = 1;
clearJobId() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
optional string jobId = 1;
clearJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
optional int64 job_id = 1;
clearJobId() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional int64 job_id = 4;
clearJobId() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
optional int64 job_id = 1;
clearJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string job_id = 8;
clearJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string job_id = 7;
clearJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string job_id = 8;
clearJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions.Builder
optional bool jobIdOnly = 3;
clearJobIds() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 1;
clearJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
clearJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
clearJobInfos() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
clearJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional int64 jobMasterId = 1;
clearJobMasterStatus() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
clearJobProgress() - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
clearJobSource() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.JobSource jobSource = 3;
clearJobStatus() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional .alluxio.grpc.job.Status jobStatus = 2;
clearJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional .alluxio.grpc.job.Status job_status = 5;
clearJobStatusBlock() - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
clearJobStopped() - Method in class alluxio.grpc.StopJobPResponse.Builder
optional bool jobStopped = 1;
clearJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
clearJournalEntries() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
clearJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 journalEntriesSinceCheckpoint = 2;
clearKey() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
clearKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
clearKeys() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
clearLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_accessed_ms = 30;
clearLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastAccessTimeMs = 31;
clearLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_access_time_ms = 20;
clearLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_access_time_ms = 29;
clearLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_access_time_ms = 18;
clearLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 lastCheckpointTime = 1;
clearLastContactSec() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int32 lastContactSec = 3;
clearLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 lastHeartbeatTime = 4;
clearLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastModificationTimeMs = 14;
clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_modification_time_ms = 7;
clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_modification_time_ms = 7;
clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 last_modification_time_ms = 2;
clearLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_modification_time_ms = 7;
clearLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_modified_ms = 25;
clearLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus.Builder
optional int64 last_modified_time_ms = 3;
clearLastUpdated() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 lastUpdated = 6;
clearLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 lastUpdated = 3;
clearLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo.Builder
optional int64 lastUpdatedTime = 5;
clearLastUpdateMs() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 lastUpdateMs = 4;
clearLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
clearLayout() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
clearLayout() - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
clearLayoutData() - Method in class alluxio.grpc.table.Layout.Builder
optional bytes layout_data = 3;
clearLayoutSpec() - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
clearLayoutType() - Method in class alluxio.grpc.table.Layout.Builder
optional string layout_type = 1;
clearLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo.Builder
optional string leaderMasterAddress = 1;
clearLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 leastSignificantBits = 2;
clearLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 leastSignificantBits = 2;
clearLength() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 length = 5;
clearLength() - Method in class alluxio.grpc.Block.Builder
The block length.
clearLength() - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 length = 2;
clearLength() - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 length = 5;
clearLength() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the length of the block being committed
clearLength() - Method in class alluxio.grpc.File.Builder
file length
clearLength() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 length = 5;
clearLength() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 length = 3;
clearLength() - Method in class alluxio.grpc.Route.Builder
optional int64 length = 3;
clearLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
clearLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
clearLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
clearLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
clearLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
clearLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
clearLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 length = 3;
clearLength() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
optional int64 length = 1;
clearLength() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 length = 19;
clearLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 liveWorkerNum = 4;
clearLoadAverage() - Method in class alluxio.grpc.JobWorkerHealth.Builder
repeated double loadAverage = 2;
clearLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
clearLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions.Builder
This is deprecated since 1.1.1 and will be removed in 2.0.
clearLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
clearLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions.Builder
No data will be transferred.
clearLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest.Builder
If set false, only the metadata of file will be loaded.
clearLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool loadMetadataOnly = 4;
clearLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool load_metadata_only = 9;
clearLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
clearLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
clearLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
clearLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string load_path = 1;
clearLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
clearLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool localFileSystem = 1;
clearLocation() - Method in class alluxio.grpc.table.Database.Builder
optional string location = 3;
clearLocation() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional string location = 2;
clearLocations() - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
clearLongestRunning() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
clearLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
clearLongType() - Method in class alluxio.grpc.table.Value.Builder
int64 long_type = 1;
clearLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
clearLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
clearLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
clearLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clearLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
clearLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 lostWorkerNum = 5;
clearLow() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
clearLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
clearLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
clearLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double low_value = 1;
clearLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 low_value = 1;
clearMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
clearMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
clearMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
clearMasterAddress() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
clearMasterAddresses() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
clearMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse.Builder
The hostname of the master that did the checkpoint
clearMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
optional int64 masterId = 1;
clearMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
optional int64 masterId = 1;
clearMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
clearMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
clearMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional int64 masterId = 1;
clearMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
clearMasterVersions() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
clearMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 max_col_len = 1;
clearMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 max_col_len = 1;
clearMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional int32 maxUfsReadConcurrency = 2;
clearMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
clearMediumType() - Method in class alluxio.grpc.BlockLocation.Builder
optional string mediumType = 4;
clearMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string mediumType = 2;
clearMediumType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional string mediumType = 7;
clearMediumType() - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
clearMediumType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional string medium_type = 2;
clearMediumType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional string medium_type = 8;
clearMediumType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
clearMediumType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
clearMediumType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
clearMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string mediumType = 3;
clearMediumType() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
clearMessage() - Method in class alluxio.grpc.BlockStatus.Builder
A developer-facing error message
clearMessage() - Method in class alluxio.grpc.FileFailure.Builder
A developer-facing error message
clearMessage() - Method in class alluxio.grpc.LoadFileFailure.Builder
A developer-facing error message
clearMessage() - Method in class alluxio.grpc.RouteFailure.Builder
A developer-facing error message
clearMessage() - Method in class alluxio.grpc.SaslMessage.Builder
optional bytes message = 2;
clearMessage() - Method in class alluxio.grpc.TransportMessage.Builder
optional bytes message = 3;
clearMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
clearMessageType() - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
clearMetrics(ClearMetricsRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Clear the worker metrics.
clearMetrics(ClearMetricsRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
clearMetrics() - Method in interface alluxio.client.metrics.MetricsMasterClient
Clear the master metrics.
clearMetrics() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
 
clearMetrics() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
clearMetrics(ClearMetricsRequest, StreamObserver<ClearMetricsResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
TODO(lu) Move to metrics worker
clearMetrics(ClearMetricsRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
TODO(lu) Move to metrics worker
clearMetrics(ClearMetricsRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
TODO(lu) Move to metrics worker
clearMetrics(ClearMetricsRequest, StreamObserver<ClearMetricsResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
TODO(lu) Move to metrics worker
clearMetrics() - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
clearMetrics() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
clearMetrics(ClearMetricsPRequest, StreamObserver<ClearMetricsPResponse>) - Method in interface alluxio.grpc.MetricsMasterClientServiceGrpc.AsyncService
Clears the metrics in the cluster.
clearMetrics(ClearMetricsPRequest) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceBlockingStub
Clears the metrics in the cluster.
clearMetrics(ClearMetricsPRequest) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub
Clears the metrics in the cluster.
clearMetrics(ClearMetricsPRequest, StreamObserver<ClearMetricsPResponse>) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub
Clears the metrics in the cluster.
clearMetrics() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
clearMetrics() - Method in interface alluxio.master.metrics.MetricsMaster
Clear metrics in the current master.
clearMetrics(ClearMetricsPRequest, StreamObserver<ClearMetricsPResponse>) - Method in class alluxio.master.metrics.MetricsMasterClientServiceHandler
 
clearMetrics() - Method in interface alluxio.worker.block.BlockWorker
Clears the worker metrics.
ClearMetricsPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.ClearMetricsPRequest
ClearMetricsPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.ClearMetricsPRequest
ClearMetricsPRequestOrBuilder - Interface in alluxio.grpc
 
ClearMetricsPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.ClearMetricsPResponse
ClearMetricsPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.ClearMetricsPResponse
ClearMetricsPResponseOrBuilder - Interface in alluxio.grpc
 
ClearMetricsRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.ClearMetricsRequest
ClearMetricsRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.ClearMetricsRequest
ClearMetricsRequestOrBuilder - Interface in alluxio.grpc
 
ClearMetricsResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.ClearMetricsResponse
ClearMetricsResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.ClearMetricsResponse
ClearMetricsResponseOrBuilder - Interface in alluxio.grpc
 
clearMetricType() - Method in class alluxio.grpc.Metric.Builder
required .alluxio.grpc.MetricType metricType = 5;
clearMetricType() - Method in class alluxio.grpc.MetricValue.Builder
optional .alluxio.grpc.MetricType metricType = 6;
clearMode() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
clearMode() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
clearMode() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 mode = 18;
clearMode() - Method in class alluxio.grpc.PAcl.Builder
optional int32 mode = 4;
clearMode() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
clearMode() - Method in class alluxio.grpc.UfsStatus.Builder
optional int32 mode = 6;
clearMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int32 mode = 4;
clearMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int32 mode = 10;
clearMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 mode = 16;
clearMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int32 mode = 11;
clearMostSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 mostSignificantBits = 1;
clearMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 mostSignificantBits = 1;
clearMountId() - Method in class alluxio.grpc.Block.Builder
optional int64 mountId = 5;
clearMountId() - Method in class alluxio.grpc.File.Builder
optional int64 mountId = 4;
clearMountId() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 mountId = 23;
clearMountId() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
required int64 mountId = 1;
clearMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
the id of the ufs
clearMountId() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 mountId = 8;
clearMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int64 mount_id = 5;
clearMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 mountId = 5;
clearMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 mount_id = 1;
clearMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional int64 mount_id = 6;
clearMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional int64 mount_id = 2;
clearMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional int64 mount_id = 2;
clearMountPoint() - Method in class alluxio.grpc.FileInfo.Builder
optional bool mountPoint = 20;
clearMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
clearMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool mount_point = 2;
clearMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
clearMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
clearMsg() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
optional string msg = 1;
clearName() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string name = 1;
clearName() - Method in class alluxio.grpc.FileInfo.Builder
optional string name = 2;
clearName() - Method in class alluxio.grpc.InconsistentProperty.Builder
optional string name = 1;
clearName() - Method in class alluxio.grpc.JobInfo.Builder
Some jobs don't have these
clearName() - Method in class alluxio.grpc.ListAllPOptions.Builder
optional string name = 2;
clearName() - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
clearName() - Method in class alluxio.grpc.PolicyInfo.Builder
optional string name = 2;
clearName() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
clearName() - Method in class alluxio.grpc.UfsStatus.Builder
optional string name = 1;
clearName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
clearName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
clearName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string name = 3;
clearName() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string name = 1;
clearName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional string name = 2;
clearName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
optional string name = 1;
clearName() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string name = 6;
clearName() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional string name = 1;
clearNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
clearNewName() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_name = 5;
clearNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 new_parent_id = 4;
clearNewPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_path = 7;
clearNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
optional int64 next_container_id = 1;
clearNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set, do not try to cache the block locally when reading the data from the UFS.
clearNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
optional .alluxio.grpc.journal.NodeState node_state = 1;
clearNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 numActiveTasks = 6;
clearNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_distincts = 4;
clearNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_distincts = 4;
clearNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_distincts = 4;
clearNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_distincts = 4;
clearNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_distincts = 4;
clearNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_falses = 2;
clearNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 num_nulls = 3;
clearNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_nulls = 3;
clearNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_nulls = 3;
clearNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_nulls = 3;
clearNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_nulls = 3;
clearNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_nulls = 3;
clearNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_nulls = 3;
clearNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_trues = 1;
clearOffset() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional int64 offset = 2;
clearOffset() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 offset = 2;
clearOffset() - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
clearOffset() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 offset = 3;
clearOffset() - Method in class alluxio.grpc.WriteResponse.Builder
optional int64 offset = 1;
clearOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
clearOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
clearOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only start listing items after this many items have been processed.
clearOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
clearOffsetInFile() - Method in class alluxio.grpc.Block.Builder
The offset of the block in within ufs the file.
clearOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The offset of the block in within the file.
clearOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated. 
clearOffsetReceived() - Method in class alluxio.grpc.ReadRequest.Builder
Read receipt
clearOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated. 
clearOffsetType() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ActionInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupPStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Block.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockIdList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockLocation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.BuildVersion.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CacheRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CacheResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CheckResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Chunk.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ClientMetrics.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CmdProgress.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CmdSummary.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Command.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ConfigProperties.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ConfigProperty.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CopyRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CopyResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DeletePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DeletePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DeletePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ErrorInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.File.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileFailure.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.FsOpPId.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobCommand.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobDescription.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobProgress.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobUnused.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LoadResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MasterVersion.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Metric.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MetricValue.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPointInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MountPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.MoveResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NetAddress.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PAcl.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PAclEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PersistFile.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PMode.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PolicyInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.PolicyStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ProxyStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReadRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReadResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterCommand.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RenamePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RenamePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RenamePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RetryInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.Route.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RouteFailure.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SaslMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SnapshotData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StatusSummary.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.StorageList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.SubmitResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Constraint.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Database.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Date.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Decimal.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Domain.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Layout.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Partition.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Range.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.RangeSet.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Schema.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TableInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Transformation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.table.Value.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TierList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TransportMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UfsStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.grpc.WriteResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
clearOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
If set, only reserve space for the block.
clearOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
clearOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
clearOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
clearOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
clearOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
clearOperation() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string operation = 1;
clearOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
clearOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
clearOperationType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional .alluxio.grpc.job.OperationType operationType = 3;
clearOperationType() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.OperationType operationType = 2;
clearOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 op_time_ms = 4;
clearOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 op_time_ms = 3;
clearOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 op_time_ms = 3;
clearOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 op_time_ms = 3;
clearOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 op_time_ms = 2;
clearOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
clearOptions() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
clearOptions() - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
clearOptions() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
clearOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
clearOptions() - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
clearOptions() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
clearOptions() - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
clearOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
clearOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
clearOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
clearOptions() - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
clearOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
clearOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
clearOptions() - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
clearOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
clearOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
clearOptions() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
clearOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
clearOptions() - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
clearOptions() - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
clearOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
clearOptions() - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
clearOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
clearOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
clearOptions() - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
clearOptions() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
clearOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
clearOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
clearOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
clearOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
clearOtherBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits otherBits = 3;
clearOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string output_format = 3;
clearOverwrite() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool overwrite = 4;
clearOverwrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool overwrite = 13;
clearOverwrite() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool overwrite = 4;
clearOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool overwrite = 1;
clearOverwrite() - Method in class alluxio.grpc.WriteOptions.Builder
optional bool overwrite = 1;
clearOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool overwrite = 10;
clearOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool overwrite = 10;
clearOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_access_time = 19;
clearOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_modification_time = 8;
clearOwner() - Method in class alluxio.grpc.FileInfo.Builder
optional string owner = 16;
clearOwner() - Method in class alluxio.grpc.PAcl.Builder
optional string owner = 1;
clearOwner() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string owner = 3;
clearOwner() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string owner = 4;
clearOwner() - Method in class alluxio.grpc.UfsStatus.Builder
optional string owner = 4;
clearOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
clearOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
clearOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
clearOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
clearOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string owner = 9;
clearOwnerBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits ownerBits = 1;
clearOwnerName() - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
clearOwnerType() - Method in class alluxio.grpc.table.Database.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
clearOwningGroup() - Method in class alluxio.grpc.PAcl.Builder
optional string owningGroup = 2;
clearOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningGroup = 2;
clearOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningUser = 1;
clearPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 pageSize = 1;
clearParameter() - Method in class alluxio.grpc.table.Database.Builder
 
clearParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
clearParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
 
clearParentId() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 parentId = 10;
clearParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 parent_id = 2;
clearParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 parent_id = 2;
clearParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 parent_id = 2;
clearParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 parent_id = 7;
clearPartialListing() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool partialListing = 3;
clearPartialListing() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool partialListing = 3;
clearPartialListing() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool partialListing = 3;
clearPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool partialListing = 7;
clearPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool partialListing = 6;
clearPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool partialListing = 7;
clearPartitionCols() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
clearPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
partition name in the form of "key=value"
clearPartitions() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
clearPartitionSpec() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
clearPartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
clearPartNames() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
clearPath() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional string path = 1;
clearPath() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
the root of the subtree to check
clearPath() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
the path of the file
clearPath() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
the path of the directory
clearPath() - Method in class alluxio.grpc.CreateFilePRequest.Builder
the path of the file
clearPath() - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
clearPath() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional string path = 1;
clearPath() - Method in class alluxio.grpc.FileInfo.Builder
optional string path = 3;
clearPath() - Method in class alluxio.grpc.FreePRequest.Builder
the path of the file or directory
clearPath() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
optional string path = 1;
clearPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
the path of the file
clearPath() - Method in class alluxio.grpc.GetStatusPRequest.Builder
the path of the file or directory
clearPath() - Method in class alluxio.grpc.JobDescription.Builder
optional string path = 2;
clearPath() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
the path of the file or directory
clearPath() - Method in class alluxio.grpc.ListStatusPRequest.Builder
the path of the file or directory
clearPath() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
required string path = 1;
clearPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional string path = 1;
clearPath() - Method in class alluxio.grpc.RenamePRequest.Builder
the source path of the file or directory
clearPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
the path of the file
clearPath() - Method in class alluxio.grpc.SetAclPRequest.Builder
the path of the file or directory
clearPath() - Method in class alluxio.grpc.SetAttributePRequest.Builder
the path of the file
clearPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional string path = 1;
clearPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
clearPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
clearPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional string path = 5;
clearPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string path = 17;
clearPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string path = 25;
clearPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string path = 6;
clearPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string path = 12;
clearPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
optional string path = 1;
clearPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
optional string path = 1;
clearPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string pathConfigHash = 2;
clearPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string pathConfigHash = 4;
clearPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 pathConfigLastUpdateTime = 6;
clearPathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
clearPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
clearPattern() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
optional string pattern = 2;
clearPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
clearPersist() - Method in class alluxio.grpc.RenamePOptions.Builder
optional bool persist = 2;
clearPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
clearPersisted() - Method in class alluxio.grpc.FileInfo.Builder
optional bool persisted = 12;
clearPersisted() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool persisted = 2;
clearPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
clearPersistedFileFingerprints() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
clearPersistedFiles() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the list of persisted files
clearPersistenceState() - Method in class alluxio.grpc.FileInfo.Builder
optional string persistenceState = 19;
clearPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
clearPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
clearPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string persistence_state = 4;
clearPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persistence_state = 8;
clearPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 persistenceWaitTime = 10;
clearPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional int64 persistenceWaitTime = 2;
clearPersistFiles() - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
clearPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 persist_job_id = 22;
clearPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 persistJobId = 11;
clearPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 persist_job_id = 10;
clearPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Used for recovering in-progress file persist jobs on master start.
clearPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persist_job_temp_ufs_path = 24;
clearPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
clearPinned() - Method in class alluxio.grpc.FileInfo.Builder
optional bool pinned = 10;
clearPinned() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool pinned = 1;
clearPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool pinned = 5;
clearPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool pinned = 5;
clearPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool pinned = 3;
clearPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool pinned = 5;
clearPinnedFileIds() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
TODO(adit): set replacement?
clearPinnedMedia() - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
clearPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool pin_on_create = 9;
clearPolicy() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
clearPolicy() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
clearPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
clearPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional string policyName = 1;
clearPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string policyName = 1;
clearPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional string policyName = 1;
clearPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional string policyName = 1;
clearPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
optional string policyName = 1;
clearPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
clearPositionShort() - Method in class alluxio.grpc.ReadRequest.Builder
Is position read to a small buffer
clearPositionShort() - Method in class alluxio.grpc.UfsReadOptions.Builder
is position short or not, used for HDFS performance optimization.
clearPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only match files with a given prefix.
clearPreviousVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 previous_version = 9;
clearPriority() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional int32 priority = 4;
clearProgressPercentage() - Method in class alluxio.grpc.CmdSummary.Builder
optional float progressPercentage = 9;
clearProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional string progressReport = 1;
clearPromote() - Method in class alluxio.grpc.ReadRequest.Builder
Whether the block should be promoted before reading
clearPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
clearPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
Whether the block should be promoted before reading
clearProperties() - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
clearProperties() - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
clearProperties() - Method in class alluxio.grpc.MountPointInfo.Builder
 
clearProperties() - Method in class alluxio.grpc.MountPOptions.Builder
 
clearProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
clearProperties() - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
clearProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
clearProperties() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
clearProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
clearProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
clearProxyStatuses() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
clearRaftAddress() - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
clearRaftJournal() - Method in class alluxio.grpc.MasterInfo.Builder
optional bool raftJournal = 12;
clearRange() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
clearRanges() - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
clearRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool rawValue = 1;
clearReadOnly() - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool readOnly = 5;
clearReadOnly() - Method in class alluxio.grpc.MountPOptions.Builder
optional bool readOnly = 1;
clearReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
clearReadType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.ReadPType readType = 1;
clearRecentActivities() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
clearRecentFailures() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
clearRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool recursive = 1;
clearRecursive() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool recursive = 2;
clearRecursive() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool recursive = 1;
clearRecursive() - Method in class alluxio.grpc.FreePOptions.Builder
optional bool recursive = 1;
clearRecursive() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional bool recursive = 4;
clearRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
whether to load metadata recursively
clearRecursive() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional bool recursive = 2;
clearRecursive() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool recursive = 6;
clearRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, we now write one journal entry per inode removed
clearRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional bool recursive = 5;
clearRegisterCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
clearRemovedBlockIds() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the list of removed block ids
clearRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
clearRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
clearRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
clearReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationDurable = 6;
clearReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_durable = 24;
clearReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_durable = 20;
clearReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMax = 4;
clearReplicationMax() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMax = 29;
clearReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMax = 7;
clearReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_max = 20;
clearReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_max = 13;
clearReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_max = 8;
clearReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_max = 21;
clearReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMin = 5;
clearReplicationMin() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMin = 30;
clearReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMin = 8;
clearReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_min = 21;
clearReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_min = 14;
clearReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_min = 9;
clearReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_min = 22;
clearReport() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
clearRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
optional bytes request_body = 1;
clearRequestHeader() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
clearRequestId() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
optional int64 requestId = 1;
clearRequestId() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional int64 requestId = 1;
clearResponseHeader() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
clearResult() - Method in class alluxio.grpc.JobInfo.Builder
optional bytes result = 9;
clearRetryable() - Method in class alluxio.grpc.BlockStatus.Builder
optional bool retryable = 4;
clearRetryable() - Method in class alluxio.grpc.FileFailure.Builder
optional bool retryable = 4;
clearRetryable() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional bool retryable = 4;
clearRetryable() - Method in class alluxio.grpc.RouteFailure.Builder
optional bool retryable = 4;
clearRevision() - Method in class alluxio.grpc.BuildVersion.Builder
the git revision at the time of building
clearRevision() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string revision = 5;
clearRoute() - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
clearRoutes() - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
clearRoutes() - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
clearRpcPort() - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 rpcPort = 3;
clearRpcPort() - Method in class alluxio.grpc.NetAddress.Builder
optional int32 rpcPort = 2;
clearRpcPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 rpcPort = 2;
clearRunAsync() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool runAsync = 2;
clearRunTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
clearS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
clearSafeMode() - Method in class alluxio.grpc.MasterInfo.Builder
optional bool safeMode = 4;
clearScale() - Method in class alluxio.grpc.table.Decimal.Builder
force using scale first in Decimal.compareTo
clearScanCompleted() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanCompleted = 4;
clearScanPendingAction() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanPendingAction = 3;
clearScanStartedMs() - Method in class alluxio.grpc.PolicyStatus.Builder
scan status
clearScanTotal() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanTotal = 2;
clearSchema() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
clearSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 sequence_number = 2;
clearSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
shared fields.
clearSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string serde = 1;
clearSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
clearSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
clearServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
clearServerAddress() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
clearServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
clearServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
clearServerInfo() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
clearServerState() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
clearServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
clearSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
clearSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
clearSetBlocks() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
Overwrite the blocks list
clearSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
clearShared() - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool shared = 7;
clearShared() - Method in class alluxio.grpc.MountPOptions.Builder
optional bool shared = 3;
clearShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
clearShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 should_persist_time = 27;
clearShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 should_persist_time = 28;
clearSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional bool skewed = 4;
clearSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest.Builder
optional bool skip_if_exists = 4;
clearSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool skipIfExists = 5;
clearSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool skip_if_exists = 10;
clearSnapshotIndex() - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotIndex = 2;
clearSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotIndex = 2;
clearSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
clearSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
clearSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
clearSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
clearSnapshotTerm() - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotTerm = 1;
clearSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotTerm = 1;
clearSortedBy() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
clearSource() - Method in class alluxio.grpc.ClientMetrics.Builder
optional string source = 1;
clearSource() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string source = 2;
clearSource() - Method in class alluxio.grpc.Metric.Builder
optional string source = 2;
clearSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
clearSourceHost() - Method in class alluxio.grpc.CacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
clearSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
clearSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int32 source_port = 3;
clearSourcePort() - Method in class alluxio.grpc.CacheRequest.Builder
optional int32 source_port = 3;
clearSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
clearSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 space_to_reserve = 10;
clearSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
clearSpec() - Method in class alluxio.grpc.table.LayoutSpec.Builder
optional string spec = 1;
clearSpec() - Method in class alluxio.grpc.table.PartitionSpec.Builder
optional string spec = 1;
clearSrc() - Method in class alluxio.grpc.Route.Builder
required string src = 1;
clearSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string src = 1;
clearSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string src = 1;
clearSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string srcPath = 2;
clearStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start the listing after this path.
clearStartTime() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional int64 startTime = 3;
clearStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional int64 startTime = 2;
clearStartTime() - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 startTime = 3;
clearStartTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 startTimeMs = 5;
clearStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 startTimeMs = 2;
clearStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 startTimeMs = 2;
clearStartTimeMs() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 startTimeMs = 7;
clearState() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional string state = 1;
clearState() - Method in class alluxio.grpc.MasterVersion.Builder
optional string state = 3;
clearState() - Method in class alluxio.grpc.ProxyStatus.Builder
optional string state = 2;
clearState() - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
clearState() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
clearState() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 2;
clearState() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
clearStatistics() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
clearStatistics() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
clearStats() - Method in class alluxio.grpc.table.Layout.Builder
 
clearStatus() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.Status status = 4;
clearStatus() - Method in class alluxio.grpc.ConfigCheckReport.Builder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
clearStatus() - Method in class alluxio.grpc.CopyResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
clearStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
clearStatus() - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.Status status = 4;
clearStatus() - Method in class alluxio.grpc.JobProgress.Builder
optional .alluxio.grpc.job.Status status = 7;
clearStatus() - Method in class alluxio.grpc.ListAllPOptions.Builder
repeated .alluxio.grpc.job.Status status = 1;
clearStatus() - Method in class alluxio.grpc.LoadFileResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
clearStatus() - Method in class alluxio.grpc.LoadResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
clearStatus() - Method in class alluxio.grpc.MoveResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
clearStatus() - Method in class alluxio.grpc.StatusSummary.Builder
optional .alluxio.grpc.job.Status status = 1;
clearStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
clearStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
clearStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
clearStorage() - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
clearStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
clearStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
clearStorageTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
clearStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
clearStringType() - Method in class alluxio.grpc.table.Value.Builder
string string_type = 3;
clearStringValue() - Method in class alluxio.grpc.MetricValue.Builder
optional string stringValue = 2;
clearSubject() - Method in class alluxio.grpc.PAclEntry.Builder
optional string subject = 2;
clearSubject() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional string subject = 2;
clearSubmissionTime() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 submissionTime = 5;
clearSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
TODO(gpang): remove in favor of status
clearSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
optional bool success = 1;
clearSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
TODO(gpang): remove in favor of status
clearSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
clearSummaryPerStatus() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
clearSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 syncIntervalMs = 1;
clearSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool syncParentNextTime = 5;
clearSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional string syncpoint_path = 1;
clearSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional string syncpoint_path = 1;
clearSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
clearTable() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
clearTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
clearTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string table_name = 4;
clearTableName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string table_name = 2;
clearTableName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string table_name = 2;
clearTablesErrors() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
clearTablesIgnored() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
clearTablesRemoved() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
clearTablesUnchanged() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
clearTablesUpdated() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
clearTag() - Method in class alluxio.grpc.UfsReadOptions.Builder
required string tag = 1;
clearTags() - Method in class alluxio.grpc.Metric.Builder
 
clearTargetDirectory() - Method in class alluxio.grpc.BackupPRequest.Builder
optional string targetDirectory = 2;
clearTaskArgs() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes taskArgs = 4;
clearTaskId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 taskId = 2;
clearTaskId() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 taskId = 2;
clearTaskInfos() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
clearTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 taskPoolSize = 5;
clearTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
optional int32 taskPoolSize = 1;
clearTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string temp_ufs_path = 23;
clearTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string tempUfsPath = 12;
clearTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string temp_ufs_path = 11;
clearThreads() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
clearThroughput() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
removes the list of all throughput after worker aggregation.
clearTier() - Method in class alluxio.grpc.WriteRequestCommand.Builder
This is only applicable for block write.
clearTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
clearTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for block write.
clearTier() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string tier = 2;
clearTierAlias() - Method in class alluxio.grpc.BlockLocation.Builder
optional string tierAlias = 3;
clearTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string tierAlias = 1;
clearTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the alias of the target tier
clearTiers() - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
clearTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string timeExpression = 4;
clearTimer(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Removes a timer name from the scheduler if it exists.
clearTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clearTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
required string transferId = 1;
clearTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
required string transferId = 1;
clearTransformations() - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
clearTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
clearTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
the timestamp in nanoseconds when this FileStatus is refreshed
clearTtl() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 ttl = 15;
clearTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 ttl = 2;
clearTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 ttl = 13;
clearTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 ttl = 13;
clearTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
clearTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 ttl = 12;
clearTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 ttl = 4;
clearTtlAction() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.TtlAction ttlAction = 22;
clearTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.TtlAction ttlAction = 3;
clearTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
clearTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
clearTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
clearTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
clearTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.grpc.TtlAction ttl_action = 5;
clearTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 tx_id = 2;
clearType() - Method in class alluxio.grpc.JobDescription.Builder
required string type = 1;
clearType() - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.JobType type = 8;
clearType() - Method in class alluxio.grpc.PAclEntry.Builder
optional .alluxio.grpc.file.PAclEntryType type = 1;
clearType() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string type = 3;
clearType() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
clearType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.grpc.block.RequestType type = 1;
clearType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
clearType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
clearType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional .alluxio.proto.shared.AclEntryType type = 1;
clearUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
clearUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
clearUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
clearUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsCapacityBytes = 3 [default = -1];
clearUfsFileStatus() - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
clearUfsFingerprint() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsFingerprint = 26;
clearUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
clearUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
clearUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
clearUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string ufs_fingerprint = 15;
clearUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string ufs_fingerprint = 11;
clearUfsFullPath() - Method in class alluxio.grpc.UfsStatus.Builder
optional string ufs_full_path = 8;
clearUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
clearUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional int64 ufsLength = 1;
clearUfsLocations() - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
clearUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
clearUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
clearUfsPath() - Method in class alluxio.grpc.Block.Builder
optional string ufs_path = 3;
clearUfsPath() - Method in class alluxio.grpc.File.Builder
optional string ufs_path = 2;
clearUfsPath() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsPath = 4;
clearUfsPath() - Method in class alluxio.grpc.MountPRequest.Builder
the path of the under file system
clearUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
the ufs path
clearUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
clearUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
clearUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
clearUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
clearUfsReadOptions() - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
clearUfsReadOptions() - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
clearUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
clearUfsStatus() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
clearUfsStatus() - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
clearUfsStringLocations() - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
clearUfsType() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsType = 35;
clearUfsType() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
clearUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
required string ufsUri = 1;
clearUfsUri() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsUri = 1;
clearUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
optional string ufsUri = 1;
clearUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsUsedBytes = 4 [default = -1];
clearUnchecked() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool unchecked = 3;
clearUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 unfinishedTasks = 7;
clearUnscaled() - Method in class alluxio.grpc.table.Decimal.Builder
required bytes unscaled = 2;
clearUnused0() - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
clearUnused1() - Method in class alluxio.grpc.JobInfo.Builder
formerly result
clearUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
clearUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
clearUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
clearUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional bool updateLastAccessTime = 4 [default = true];
clearUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool updateTimestamps = 4 [default = true];
clearUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
clearUpTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 upTimeMs = 6;
clearUri() - Method in class alluxio.grpc.UfsInfo.Builder
optional string uri = 1;
clearUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 usedBytes = 6;
clearUsedBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 usedBytes = 6;
clearUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the space used in bytes on the target tier
clearUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
clearUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
clearUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clearUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
 
clearUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool useMultipartUpload = 17;
clearUser() - Method in class alluxio.grpc.UfsReadOptions.Builder
optional string user = 4;
clearUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
clearUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional string user = 6;
clearUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional string user = 5;
clearUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional string user = 6;
clearUserActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
clearUuid() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional string uuid = 3;
clearUuid() - Method in class alluxio.grpc.CreateFilePResponse.Builder
uuid of its open file handle
clearValue() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
clearValue() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
clearValue() - Method in class alluxio.grpc.Metric.Builder
optional double value = 4;
clearValue() - Method in class alluxio.grpc.table.Value.Builder
 
clearValue() - Method in class alluxio.grpc.WriteRequest.Builder
 
clearValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
clearValue() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string value = 3;
clearValues() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
clearValues() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
clearValues() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
clearValueSet() - Method in class alluxio.grpc.table.Domain.Builder
 
clearVerbose() - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional bool verbose = 2;
clearVerify() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool verify = 2;
clearVerify() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool verify = 2;
clearVerify() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool verify = 2;
clearVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool verify = 5;
clearVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool verify = 4;
clearVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool verify = 5;
clearVersion() - Method in class alluxio.grpc.BuildVersion.Builder
the project version
clearVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
optional int64 version = 1;
clearVersion() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
clearVersion() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
clearVersion() - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
clearVersion() - Method in class alluxio.grpc.MasterVersion.Builder
optional string version = 2;
clearVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
clearVersion() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
clearVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
clearVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
clearVersion() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string version = 4;
clearVersion() - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version = 4;
clearVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version = 10;
clearVersion() - Method in class alluxio.grpc.WorkerIdentity.Builder
version of the definition of the opaque identifier
clearVersionCreationTime() - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version_creation_time = 5;
clearVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version_creation_time = 11;
clearWarns() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
clearWebPort() - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 webPort = 8;
clearWebPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 webPort = 4;
clearWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
optional bool white_list = 2;
clearWorkerAddress() - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
clearWorkerAddresses() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
clearWorkerHealths() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
clearWorkerHost() - Method in class alluxio.grpc.JobInfo.Builder
optional string workerHost = 12;
clearWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
required string workerHostname = 1;
clearWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
required string workerHostname = 1;
clearWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the id of the worker
clearWorkerId() - Method in class alluxio.grpc.BlockLocation.Builder
optional int64 workerId = 1;
clearWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the worker
clearWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the id of the worker
clearWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
optional int64 workerId = 1;
clearWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 workerId = 1;
clearWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
optional int64 workerId = 1;
clearWorkerId() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 workerId = 1;
clearWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional int64 workerId = 1;
clearWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the id of the worker
clearWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional int64 worker_id = 1;
clearWorkerInfos() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
clearWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
clearWorkerLostStorageInfo() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
clearWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
clearWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
clearWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
clearWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
clearWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional int64 workerWebPort = 2;
clearWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
optional int64 workerWebPort = 2;
clearWriteOptions() - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
clearWriteOptions() - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
clearWriteTier() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 writeTier = 7;
clearWriteType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
clearWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
clearWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
clearWriteType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
clearWriteType() - Method in class alluxio.grpc.WriteOptions.Builder
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
clearXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
clearXattr() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
clearXattr() - Method in class alluxio.grpc.FileInfo.Builder
 
clearXattr() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
clearXattr() - Method in class alluxio.grpc.UfsStatus.Builder
 
clearXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
clearXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
clearXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
clearXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
clearXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
clearXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
clearXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
clearXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
clearZookeeperAddresses() - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
CLI_VALUE - Static variable in enum alluxio.grpc.JobSource
CLI = 1;
CliConfig - Interface in alluxio.job.cmd
A Cmd config for Cli.
Client - Interface in alluxio
Interface for a client in the Alluxio system.
client() - Method in class alluxio.master.transport.GrpcMessagingTransport
Creates a new Grpc messaging client.
CLIENT_BLOCK_MASTER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BLOCK_READ_CHUNK_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BLOCK_WORKER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BUSY_EXCEPTION_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_READ_FROM_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_READ_FROM_WORKERS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_TO_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_TO_WORKERS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_DISCARDED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_CACHE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_IN_STREAM_BUFFER - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_REQUESTED_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_WRITTEN_CACHE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CLEAN_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CLEANUP_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CLEANUP_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CREATE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_FROM_STORE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_NON_EXISTING_PAGE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_EXTERNAL_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_STORE_READ_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_HIT_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGE_READ_CACHE_TIME_NS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGE_READ_EXTERNAL_TIME_NS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES_AGES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES_DISCARDED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES_INVALIDATED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_POSITION_READ_FALLBACK - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_ASYNC_REJECTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_BENIGN_RACING_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_EVICTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_INSUFFICIENT_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_STORE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_STORE_WRITE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_STORE_WRITE_NO_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_BYTES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_BYTES_HIT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_BYTES_READ - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_FALSE_POSITIVE_RATIO - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_PAGES_HIT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_PAGES_READ - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_AVAILABLE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_USED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_USED_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STATE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_DELETE_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_GET_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_PUT_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_THREADS_REJECTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_DEFAULT_HIVE_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_FILE_SYSTEM_MASTER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_META_DATA_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_TYPE_OPTION_NAME - Static variable in class alluxio.stress.common.FileSystemParameters
 
CLIENT_UFS_FALLBACK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_UFS_FALLBACK_READ_BYTES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_VALUE - Static variable in enum alluxio.grpc.Scope
CLIENT = 4;
CLIENT_WRITE_TO_UFS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
CLIENT_WRITE_TO_UFS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
clientClosed(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
Called when an open block client is closed.
ClientContext - Class in alluxio
A ClientContext contains information required and pertaining to making network connections and performing operations with remote Alluxio processes.
ClientContext(ClientContext) - Constructor for class alluxio.ClientContext
This constructor does not create a copy of the configuration.
ClientContext(Subject, AlluxioConfiguration) - Constructor for class alluxio.ClientContext
 
ClientContextServerInjector - Class in alluxio.security.authentication
Server side interceptor that is used to put remote client's IP Address to thread local storage.
ClientContextServerInjector() - Constructor for class alluxio.security.authentication.ClientContextServerInjector
 
clientHeartbeat(String, List<Metric>) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
clientHeartbeat(String, List<Metric>) - Method in interface alluxio.master.metrics.MetricsMaster
Handles the client's heartbeat request for metrics collection.
CLIENTID_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
 
ClientIOOperation - Enum in alluxio.stress.client
The operations for the client io stress tests.
ClientIOOperationConverter() - Constructor for class alluxio.stress.client.ClientIOParameters.ClientIOOperationConverter
 
ClientIOParameters - Class in alluxio.stress.client
This holds all the parameters.
ClientIOParameters() - Constructor for class alluxio.stress.client.ClientIOParameters
 
ClientIOParameters.ClientIOOperationConverter - Class in alluxio.stress.client
Converts from String to ClientIOOperation instance.
ClientIOSummary - Class in alluxio.stress.client
The summary for Fuse IO stress bench.
ClientIOSummary() - Constructor for class alluxio.stress.client.ClientIOSummary
Default constructor required for json deserialization.
ClientIOSummary(ClientIOParameters, BaseParameters, Map<String, ClientIOTaskResult>, Map<Integer, Float>) - Constructor for class alluxio.stress.client.ClientIOSummary
Creates an instance.
ClientIOSummary.GraphGenerator - Class in alluxio.stress.client
The graph generator for this summary.
ClientIOTaskResult - Class in alluxio.stress.client
The task result for the master stress tests.
ClientIOTaskResult() - Constructor for class alluxio.stress.client.ClientIOTaskResult
Creates an instance.
ClientIOTaskResult.GraphGenerator - Class in alluxio.stress.client
The graph generator for this summary.
ClientIOTaskResult.ThreadCountResult - Class in alluxio.stress.client
A result for a single thread count test.
ClientMasterSync - Class in alluxio.client.metrics
Task that carries the client metrics information to master through heartheat.
ClientMasterSync(String, ClientContext, MasterInquireClient) - Constructor for class alluxio.client.metrics.ClientMasterSync
Constructs a new ClientMasterSync.
ClientMetrics - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.ClientMetrics
ClientMetrics.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.ClientMetrics
CLIENTMETRICS_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricsHeartbeatPOptions
 
ClientMetricsOrBuilder - Interface in alluxio.grpc
 
clientOpened(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
Called when a new block client is opened.
ClientPool - Class in alluxio.master
Keeps a collection of all clients (FileSystem) returned.
ClientPoolKey(SocketAddress, String) - Constructor for class alluxio.client.file.FileSystemContext.ClientPoolKey
 
ClientRWLock - Class in alluxio.concurrent
Read/write lock associated with clients rather than threads.
ClientRWLock(int) - Constructor for class alluxio.concurrent.ClientRWLock
Constructs a new ClientRWLock.
Clients - Class in alluxio.multi.process
Container for various Alluxio clients.
Clients(FileSystem, FileSystemMasterClient, MetaMasterClient, BlockMasterClient) - Constructor for class alluxio.multi.process.Clients
 
ClientVersionClientInjector - Class in alluxio.grpc
Client side interceptor that is used to set the request header for the client version.
ClientVersionClientInjector() - Constructor for class alluxio.grpc.ClientVersionClientInjector
 
ClockCuckooFilter<T> - Interface in alluxio.client.file.cache.cuckoofilter
This interface represents a clock cuckoo filter that supports Put/Get/Delete operations.
ClockCuckooShadowCacheManager - Class in alluxio.client.file.cache
This class is a shadow cache with ClockCuckooFilter implementation.
ClockCuckooShadowCacheManager(AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.ClockCuckooShadowCacheManager
Create a ClockCuckooShadowCacheManager.
clone() - Method in class alluxio.grpc.ActionInfo.Builder
 
clone() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
clone() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
clone() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
clone() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
clone() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
clone() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
clone() - Method in class alluxio.grpc.BackupPOptions.Builder
 
clone() - Method in class alluxio.grpc.BackupPRequest.Builder
 
clone() - Method in class alluxio.grpc.BackupPStatus.Builder
 
clone() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.Block.Builder
 
clone() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
clone() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
clone() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
clone() - Method in class alluxio.grpc.BlockIdList.Builder
 
clone() - Method in class alluxio.grpc.BlockInfo.Builder
 
clone() - Method in class alluxio.grpc.BlockLocation.Builder
 
clone() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
clone() - Method in class alluxio.grpc.BlockStatus.Builder
 
clone() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
clone() - Method in class alluxio.grpc.BuildVersion.Builder
 
clone() - Method in class alluxio.grpc.CacheRequest.Builder
 
clone() - Method in class alluxio.grpc.CacheResponse.Builder
 
clone() - Method in class alluxio.grpc.CancelPOptions.Builder
 
clone() - Method in class alluxio.grpc.CancelPRequest.Builder
 
clone() - Method in class alluxio.grpc.CancelPResponse.Builder
 
clone() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
clone() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
clone() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
clone() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
clone() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
clone() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
clone() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
clone() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
clone() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
clone() - Method in class alluxio.grpc.CheckRequest.Builder
 
clone() - Method in class alluxio.grpc.CheckResponse.Builder
 
clone() - Method in class alluxio.grpc.Chunk.Builder
 
clone() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
clone() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
clone() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
clone() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
clone() - Method in class alluxio.grpc.ClientMetrics.Builder
 
clone() - Method in class alluxio.grpc.CmdProgress.Builder
 
clone() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
clone() - Method in class alluxio.grpc.CmdSummary.Builder
 
clone() - Method in class alluxio.grpc.Command.Builder
 
clone() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
clone() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
clone() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
clone() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
clone() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
clone() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
clone() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
clone() - Method in class alluxio.grpc.ConfigProperties.Builder
 
clone() - Method in class alluxio.grpc.ConfigProperty.Builder
 
clone() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
clone() - Method in class alluxio.grpc.CopyRequest.Builder
 
clone() - Method in class alluxio.grpc.CopyResponse.Builder
 
clone() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
clone() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
clone() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
clone() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
clone() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
clone() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
clone() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
clone() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
clone() - Method in class alluxio.grpc.DeletePOptions.Builder
 
clone() - Method in class alluxio.grpc.DeletePRequest.Builder
 
clone() - Method in class alluxio.grpc.DeletePResponse.Builder
 
clone() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.ErrorInfo.Builder
 
clone() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
clone() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
clone() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
clone() - Method in class alluxio.grpc.File.Builder
 
clone() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
clone() - Method in class alluxio.grpc.FileFailure.Builder
 
clone() - Method in class alluxio.grpc.FileInfo.Builder
 
clone() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
clone() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
clone() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
clone() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
clone() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
clone() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
clone() - Method in class alluxio.grpc.FreePOptions.Builder
 
clone() - Method in class alluxio.grpc.FreePRequest.Builder
 
clone() - Method in class alluxio.grpc.FreePResponse.Builder
 
clone() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
clone() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
clone() - Method in class alluxio.grpc.FsOpPId.Builder
 
clone() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
clone() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
clone() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
clone() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
clone() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
clone() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
clone() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
clone() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
clone() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
clone() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
clone() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
clone() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
clone() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
clone() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
clone() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
clone() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
clone() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
clone() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
clone() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
clone() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
clone() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
clone() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
clone() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
clone() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
clone() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
clone() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
clone() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
clone() - Method in class alluxio.grpc.JobCommand.Builder
 
clone() - Method in class alluxio.grpc.JobDescription.Builder
 
clone() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
clone() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
clone() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
clone() - Method in class alluxio.grpc.JobInfo.Builder
 
clone() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
clone() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
clone() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
clone() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
clone() - Method in class alluxio.grpc.JobProgress.Builder
 
clone() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
clone() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
clone() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
clone() - Method in class alluxio.grpc.JobUnused.Builder
 
clone() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
clone() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
clone() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
clone() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
clone() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
clone() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
clone() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
clone() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
clone() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
clone() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
clone() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
clone() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
clone() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
clone() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
clone() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
clone() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
clone() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
clone() - Method in class alluxio.grpc.LoadRequest.Builder
 
clone() - Method in class alluxio.grpc.LoadResponse.Builder
 
clone() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
clone() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
clone() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
clone() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
clone() - Method in class alluxio.grpc.MasterInfo.Builder
 
clone() - Method in class alluxio.grpc.MasterVersion.Builder
 
clone() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
clone() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
clone() - Method in class alluxio.grpc.Metric.Builder
 
clone() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
clone() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
clone() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
clone() - Method in class alluxio.grpc.MetricValue.Builder
 
clone() - Method in class alluxio.grpc.MountPointInfo.Builder
 
clone() - Method in class alluxio.grpc.MountPOptions.Builder
 
clone() - Method in class alluxio.grpc.MountPRequest.Builder
 
clone() - Method in class alluxio.grpc.MountPResponse.Builder
 
clone() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
clone() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
clone() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
clone() - Method in class alluxio.grpc.MoveRequest.Builder
 
clone() - Method in class alluxio.grpc.MoveResponse.Builder
 
clone() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
clone() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
clone() - Method in class alluxio.grpc.NetAddress.Builder
 
clone() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
clone() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
clone() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
clone() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
clone() - Method in class alluxio.grpc.PAcl.Builder
 
clone() - Method in class alluxio.grpc.PAclEntry.Builder
 
clone() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
clone() - Method in class alluxio.grpc.PersistFile.Builder
 
clone() - Method in class alluxio.grpc.PMode.Builder
 
clone() - Method in class alluxio.grpc.PolicyInfo.Builder
 
clone() - Method in class alluxio.grpc.PolicyStatus.Builder
 
clone() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
clone() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
clone() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
clone() - Method in class alluxio.grpc.ProxyStatus.Builder
 
clone() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
clone() - Method in class alluxio.grpc.ReadRequest.Builder
 
clone() - Method in class alluxio.grpc.ReadResponse.Builder
 
clone() - Method in class alluxio.grpc.RegisterCommand.Builder
 
clone() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
clone() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
clone() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
clone() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
clone() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
clone() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
clone() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
clone() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
clone() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
clone() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
clone() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
clone() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
clone() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
clone() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
clone() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
clone() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
clone() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
clone() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
clone() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
clone() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
clone() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
clone() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
clone() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
clone() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
clone() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
clone() - Method in class alluxio.grpc.RenamePOptions.Builder
 
clone() - Method in class alluxio.grpc.RenamePRequest.Builder
 
clone() - Method in class alluxio.grpc.RenamePResponse.Builder
 
clone() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
clone() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
clone() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
clone() - Method in class alluxio.grpc.RetryInfo.Builder
 
clone() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
clone() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
clone() - Method in class alluxio.grpc.Route.Builder
 
clone() - Method in class alluxio.grpc.RouteFailure.Builder
 
clone() - Method in class alluxio.grpc.RunPOptions.Builder
 
clone() - Method in class alluxio.grpc.RunPRequest.Builder
 
clone() - Method in class alluxio.grpc.RunPResponse.Builder
 
clone() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
clone() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
clone() - Method in class alluxio.grpc.SaslMessage.Builder
 
clone() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
clone() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
clone() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
clone() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
clone() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
clone() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
clone() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
clone() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
clone() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
clone() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
clone() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
clone() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
clone() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
clone() - Method in class alluxio.grpc.SnapshotData.Builder
 
clone() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
clone() - Method in class alluxio.grpc.StatusSummary.Builder
 
clone() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
clone() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
clone() - Method in class alluxio.grpc.StorageList.Builder
 
clone() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
clone() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
clone() - Method in class alluxio.grpc.SubmitOptions.Builder
 
clone() - Method in class alluxio.grpc.SubmitRequest.Builder
 
clone() - Method in class alluxio.grpc.SubmitResponse.Builder
 
clone() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
clone() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
clone() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
clone() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
clone() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
clone() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
clone() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
clone() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
clone() - Method in class alluxio.grpc.table.Constraint.Builder
 
clone() - Method in class alluxio.grpc.table.Database.Builder
 
clone() - Method in class alluxio.grpc.table.Date.Builder
 
clone() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
clone() - Method in class alluxio.grpc.table.Decimal.Builder
 
clone() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
clone() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
clone() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
clone() - Method in class alluxio.grpc.table.Domain.Builder
 
clone() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
clone() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
clone() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
clone() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
clone() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
clone() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
clone() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
clone() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
clone() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
clone() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
clone() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
clone() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
clone() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
clone() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
clone() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
clone() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
clone() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
clone() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
clone() - Method in class alluxio.grpc.table.Layout.Builder
 
clone() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
clone() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
clone() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
clone() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
clone() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
clone() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
clone() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
clone() - Method in class alluxio.grpc.table.Partition.Builder
 
clone() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
clone() - Method in class alluxio.grpc.table.Range.Builder
 
clone() - Method in class alluxio.grpc.table.RangeSet.Builder
 
clone() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
clone() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
clone() - Method in class alluxio.grpc.table.Schema.Builder
 
clone() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
clone() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
clone() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
clone() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
clone() - Method in class alluxio.grpc.table.TableInfo.Builder
 
clone() - Method in class alluxio.grpc.table.Transformation.Builder
 
clone() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
clone() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
clone() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
clone() - Method in class alluxio.grpc.table.Value.Builder
 
clone() - Method in class alluxio.grpc.TierList.Builder
 
clone() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
clone() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
clone() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
clone() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
clone() - Method in class alluxio.grpc.TransportMessage.Builder
 
clone() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
clone() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
clone() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
clone() - Method in class alluxio.grpc.UfsInfo.Builder
 
clone() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
clone() - Method in class alluxio.grpc.UfsStatus.Builder
 
clone() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
clone() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
clone() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
clone() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
clone() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
clone() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
clone() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
clone() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
clone() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
clone() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
clone() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
clone() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
clone() - Method in class alluxio.grpc.WorkerInfo.Builder
 
clone() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
clone() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
clone() - Method in class alluxio.grpc.WriteOptions.Builder
 
clone() - Method in class alluxio.grpc.WriteRequest.Builder
 
clone() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
clone() - Method in class alluxio.grpc.WriteResponse.Builder
 
clone() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
clone() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
clone() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
clone() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
clone() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
clone() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
clone() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
clone() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
clone() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
clone() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
clone() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
clone() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
clone() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
clone() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
clone() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
clone() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
cloneByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Clones a ByteBuffer.
cloneByteBufferList(List<ByteBuffer>) - Static method in class alluxio.util.io.BufferUtils
Clones a list of ByteBuffers.
close() - Method in class alluxio.AbstractClient
Closes the connection with the remote permanently.
close() - Method in class alluxio.cli.AbstractShell
 
close() - Method in class alluxio.cli.bundler.CollectInfo
 
close() - Method in interface alluxio.cli.Command
Used to close resources created by commands.
close() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
 
close() - Method in class alluxio.cli.fsadmin.command.Context
 
close() - Method in class alluxio.client.block.stream.BlockWorkerDataReader
 
close() - Method in class alluxio.client.block.stream.BlockWorkerDataReader.Factory
 
close() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
 
close() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
close() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
close() - Method in class alluxio.client.block.stream.GrpcBlockingStream
Closes the outbound stream.
close() - Method in class alluxio.client.block.stream.GrpcDataReader
 
close() - Method in class alluxio.client.block.stream.GrpcDataReader.Factory
 
close() - Method in class alluxio.client.block.stream.GrpcDataWriter
 
close() - Method in class alluxio.client.block.stream.NettyDataReader
 
close() - Method in class alluxio.client.block.stream.NettyDataReader.Factory
 
close() - Method in class alluxio.client.block.stream.NettyDataWriter
 
close() - Method in class alluxio.client.block.stream.SharedGrpcDataReader
 
close() - Method in class alluxio.client.block.stream.SharedGrpcDataReader.Factory
 
close() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
close() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
close() - Method in class alluxio.client.file.cache.LocalCacheManager
 
close() - Method in class alluxio.client.file.cache.LocalCachePositionReader
 
close() - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
close() - Method in class alluxio.client.file.cache.store.LocalPageStore
 
close() - Method in class alluxio.client.file.cache.store.MemoryPageStore
 
close() - Method in interface alluxio.client.file.cache.store.PageStoreDir
Close the page store dir.
close() - Method in class alluxio.client.file.cache.TimeBoundPageStore
 
close() - Method in class alluxio.client.file.ConfigHashSync
 
close() - Method in class alluxio.client.file.DelegatingFileSystem
 
close() - Method in class alluxio.client.file.dora.DoraCachePositionReader
 
close() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
close() - Method in class alluxio.client.file.DoraFileOutStream
 
close() - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
close() - Method in class alluxio.client.file.FileSystemContext
Closes all the resources associated with the context.
close() - Method in class alluxio.client.file.FileSystemContextReinitializer
Shuts down the heartbeat thread immediately.
close() - Method in class alluxio.client.file.FileSystemContextReinitializer.ReinitAllowerResource
 
close() - Method in class alluxio.client.file.FileSystemContextReinitializer.ReinitBlockerResource
 
close() - Method in class alluxio.client.file.MetadataCachingFileSystem
 
close() - Method in class alluxio.client.file.PositionReadFileInStream
 
close() - Method in class alluxio.client.file.ufs.DoraOutStream
 
close() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
Shuts down the FileSystem.
close() - Method in class alluxio.client.file.ufs.UfsFileInStream
 
close() - Method in class alluxio.client.file.ufs.UfsFileOutStream
 
close() - Method in class alluxio.client.job.JobContext
Closes all the resources associated with the context.
close() - Method in class alluxio.client.job.JobMasterClientPool
 
close() - Method in class alluxio.client.metrics.ClientMasterSync
Close the metrics master client.
close() - Method in class alluxio.CloseableSupplier
 
close() - Method in class alluxio.collections.LockPool
 
close() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
close() - Method in class alluxio.fuse.AlluxioFuseUtils.CloseableFuseFileInfo
Closes the underlying resources.
close() - Method in class alluxio.fuse.CreateFileEntry
Closes the underlying open streams.
close() - Method in class alluxio.fuse.file.FuseFileEntry
Closes the underlying open streams.
close() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
close() - Method in class alluxio.fuse.file.FuseFileInStream
 
close() - Method in class alluxio.fuse.file.FuseFileOutStream
 
close() - Method in interface alluxio.fuse.file.FuseFileStream
Closes the stream and releases the lock.
close() - Method in class alluxio.fuse.file.FusePositionReader
 
close() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
close() - Method in class alluxio.fuse.meta.UpdateChecker
 
close() - Method in class alluxio.fuse.OpenFileEntry
Closes the underlying open streams.
close() - Method in interface alluxio.grpc.BufferRepository
Closes the repository and all its buffers.
close() - Method in class alluxio.grpc.DataMessageMarshaller
 
close() - Method in class alluxio.grpc.GrpcChannel
Releases the connection to the pool.
close() - Method in class alluxio.hadoop.AbstractFileSystem
 
close() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
close() - Method in class alluxio.hadoop.AlluxioHdfsPositionReader
 
close() - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
close() - Method in class alluxio.hadoop.LocalCacheFileSystem
 
close() - Method in interface alluxio.heartbeat.HeartbeatExecutor
Cleans up any resources used by the heartbeat executor.
close() - Method in class alluxio.master.AbstractMaster
 
close() - Method in interface alluxio.master.audit.AuditContext
 
close() - Method in class alluxio.master.backup.AbstractBackupRole
 
close() - Method in class alluxio.master.backup.BackupLeaderRole
 
close() - Method in class alluxio.master.backup.BackupWorkerRole
 
close() - Method in class alluxio.master.block.DefaultBlockMaster
 
close() - Method in class alluxio.master.block.DefaultBlockMaster.LostWorkerDetectionHeartbeatExecutor
 
close() - Method in class alluxio.master.block.DefaultBlockMaster.WorkerRegisterStreamGCExecutor
 
close() - Method in class alluxio.master.block.WorkerRegisterContext
 
close() - Method in class alluxio.master.ClientPool
 
close() - Method in class alluxio.master.file.DefaultBlockDeletionContext
 
close() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
close() - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
close() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
close() - Method in interface alluxio.master.file.meta.InodeLockList
Closes the lock list, releasing all locks.
close() - Method in class alluxio.master.file.meta.InodeLockManager
 
close() - Method in class alluxio.master.file.meta.InodePathPair
 
close() - Method in class alluxio.master.file.meta.InodeTree
Close resources associated with this tree instance.
close() - Method in class alluxio.master.file.meta.InodeTreeBufferedIterator
 
close() - Method in class alluxio.master.file.meta.LockedInodePath
 
close() - Method in class alluxio.master.file.meta.LockedInodePathList
 
close() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
close() - Method in class alluxio.master.file.MetadataSyncLockManager.MetadataSyncPathList
 
close() - Method in class alluxio.master.file.NoopBlockDeletionContext
 
close() - Method in class alluxio.master.file.RpcContext
 
close() - Method in class alluxio.master.job.JobMasterAuditContext
 
close() - Method in class alluxio.master.journal.AsyncJournalWriter
Closes the async writer.
close() - Method in class alluxio.master.journal.checkpoint.OptimizedCheckpointOutputStream
 
close() - Method in class alluxio.master.journal.FileSystemMergeJournalContext
 
close() - Method in interface alluxio.master.journal.JournalContext
 
close() - Method in class alluxio.master.journal.JournalEntryStreamReader
 
close() - Method in class alluxio.master.journal.MasterJournalContext
 
close() - Method in class alluxio.master.journal.MergeJournalContext
 
close() - Method in class alluxio.master.journal.MetadataSyncMergeJournalContext
 
close() - Method in class alluxio.master.journal.noop.NoopJournal
 
close() - Method in class alluxio.master.journal.NoopJournalContext
 
close() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
Resets the suspend-applier.
close() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
close() - Method in class alluxio.master.journal.raft.RaftJournal
 
close() - Method in class alluxio.master.journal.raft.RaftJournalAppender
 
close() - Method in class alluxio.master.journal.raft.RaftJournalWriter
 
close() - Method in class alluxio.master.journal.raft.RaftSnapshotManager
 
close() - Method in class alluxio.master.journal.StateChangeJournalContext
 
close() - Method in class alluxio.master.journal.ufs.UfsJournal
 
close() - Method in class alluxio.master.journal.ufs.UfsJournalFileParser
 
close() - Method in class alluxio.master.journal.ufs.UfsJournalLogWriter
 
close() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
close() - Method in interface alluxio.master.journalv0.JournalInputStream
Closes the stream.
close() - Method in interface alluxio.master.journalv0.JournalOutputStream
Closes the stream.
close() - Method in interface alluxio.master.journalv0.JournalWriter
Closes the journal.
close() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
close() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
 
close() - Method in class alluxio.master.meta.JobMasterSync
 
close() - Method in class alluxio.master.meta.JournalSpaceMonitor
 
close() - Method in class alluxio.master.meta.MetaMasterSync
 
close() - Method in class alluxio.master.meta.UpdateChecker
 
close() - Method in interface alluxio.master.metastore.BlockMetaStore
Closes the block store and releases all resources.
close() - Method in class alluxio.master.metastore.caching.Cache
 
close() - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
close() - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
close() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
close() - Method in interface alluxio.master.metastore.InodeStore
 
close() - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
 
close() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
close() - Method in class alluxio.master.metastore.rocks.RocksExclusiveLockHandle
 
close() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
close() - Method in class alluxio.master.metastore.rocks.RocksSharedLockHandle
 
close() - Method in class alluxio.master.NoopMaster
 
close() - Method in class alluxio.master.transport.GrpcMessagingClient
Closes the client.
close() - Method in class alluxio.master.transport.GrpcMessagingClientConnection
 
close() - Method in class alluxio.master.transport.GrpcMessagingConnection
Closes the connection.
close() - Method in class alluxio.master.transport.GrpcMessagingContext
Closes the context.
close() - Method in class alluxio.master.transport.GrpcMessagingServer
Closes the connection to the server if exists.
close() - Method in class alluxio.master.transport.GrpcMessagingTransport
Closes the opened clients and servers.
close() - Method in interface alluxio.master.transport.Listener
Closes the listener.
close() - Method in class alluxio.master.transport.Listeners.ListenerHolder
 
close() - Method in class alluxio.master.ZkMasterInquireClient
 
close() - Method in class alluxio.membership.DefaultServiceEntity
 
close() - Method in class alluxio.membership.EtcdMembershipManager
 
close() - Method in class alluxio.membership.MasterMembershipManager
 
close() - Method in class alluxio.membership.ServiceDiscoveryRecipe
 
close() - Method in class alluxio.membership.StaticMembershipManager
 
close() - Method in class alluxio.metrics.MetricsSystem.MultiTimerContext
Updates the timer with the difference between current and start time.
close() - Method in class alluxio.multi.process.BaseMaster
 
close() - Method in class alluxio.multi.process.Worker
 
close() - Method in interface alluxio.PositionReader
Closes the positon reader and do cleanup job if any.
close() - Method in class alluxio.proxy.ProxyMasterSync
 
close() - Method in class alluxio.proxy.s3.RangeFileInStream
 
close() - Method in class alluxio.proxy.s3.RateLimitInputStream
 
CLOSE - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
close(Integer) - Method in class alluxio.proxy.StreamsRestServiceHandler
 
close() - Method in class alluxio.Registry
Closes all Servers in reverse dependency order.
close() - Method in class alluxio.resource.CloseableResource
 
close() - Method in class alluxio.resource.DynamicResourcePool
Closes the pool and clears all the resources.
close() - Method in class alluxio.resource.LockResource
Releases the lock.
close() - Method in class alluxio.resource.NoopCloseable
 
close() - Method in class alluxio.resource.RefCountLockResource
Releases the lock and decrement the ref count if a ref counter was provided at construction time.
close() - Method in class alluxio.resource.ResourcePool
Closes the resource pool.
close() - Method in class alluxio.rocks.RocksStore
 
close() - Method in class alluxio.s3.S3AuditContext
 
close() - Method in class alluxio.security.authentication.AbstractSaslClientHandler
This is synchronized in order to protect AbstractSaslClientHandler.mSaslClient.
close() - Method in class alluxio.security.authentication.AbstractSaslServerHandler
 
close() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Stops authenticated session with the server by releasing the long poll.
close() - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
Completes authenticated channel.
close() - Method in interface alluxio.security.authentication.AuthenticationServer
Closes the server, releases all authentication sessions.
close() - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
close() - Method in interface alluxio.security.authentication.SaslClientHandler
Close the handler and dispose internal resources.
close() - Method in interface alluxio.security.authentication.SaslServerHandler
Close the handler and dispose internal resources.
close() - Method in interface alluxio.Server
Closes the server.
close() - Method in class alluxio.underfs.AbstractUfsManager
 
close() - Method in class alluxio.underfs.AtomicFileOutputStream
 
close() - Method in class alluxio.underfs.BaseUnderFileSystem
 
close() - Method in class alluxio.underfs.ByteBufferResourcePool
 
close() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
close() - Method in class alluxio.underfs.cephfs.CephInputStream
 
close() - Method in class alluxio.underfs.cephfs.CephOutputStream
 
close() - Method in class alluxio.underfs.cos.COSOutputStream
Closes this output stream.
close() - Method in class alluxio.underfs.gcs.GCSInputStream
 
close() - Method in class alluxio.underfs.gcs.GCSOutputStream
 
close() - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
 
close() - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
 
close() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
close() - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
close() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
close() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
close() - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
close() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
close() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
close() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
close() - Method in class alluxio.underfs.obs.OBSOutputStream
Closes this output stream.
close() - Method in class alluxio.underfs.oss.OSSOutputStream
Closes this output stream.
close() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
close() - Method in class alluxio.underfs.oss.StsOssClientProvider
 
close() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
close() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
close() - Method in class alluxio.underfs.UfsIOManager
Close.
close() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
close() - Method in interface alluxio.util.interfaces.Scoped
 
close() - Method in class alluxio.worker.AbstractWorker
 
close() - Method in class alluxio.worker.block.BlockMasterClientPool
 
close() - Method in class alluxio.worker.block.io.BlockClient
 
close() - Method in class alluxio.worker.block.io.BlockReadableChannel
 
close() - Method in class alluxio.worker.dora.DoraMetaManager
 
close() - Method in interface alluxio.worker.dora.DoraMetaStore
Closes the block store and releases all resources.
close() - Method in class alluxio.worker.dora.OpenFileHandle
Close this handle.
close() - Method in class alluxio.worker.dora.PagedDoraWorker
 
close() - Method in class alluxio.worker.dora.PagedFileReader
 
close() - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
Closes the RocksDb and all resources.
close() - Method in class alluxio.worker.grpc.GrpcDataServer
 
close() - Method in class alluxio.worker.job.command.CommandHandlingExecutor
 
close() - Method in class alluxio.worker.netty.FileReadHandler.FilePacketReader
 
close() - Method in class alluxio.worker.netty.NettyDataServer
 
close() - Method in class alluxio.worker.SessionCleaner
Stops the checking, once this method is called, the object should be discarded.
CLOSE_ALLUXIO_OUTSTREAM_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
CLOSE_UFS_OUTSTREAM_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
CloseableFuseFileInfo() - Constructor for class alluxio.fuse.AlluxioFuseUtils.CloseableFuseFileInfo
Constructor.
CloseableIterator<T> - Class in alluxio.resource
A CloseableIterator<T> is an iterator which requires cleanup when it is no longer in use.
CloseableIterator(Iterator<T>) - Constructor for class alluxio.resource.CloseableIterator
Creates a CloseableIterator wrapper around the given iterator.
CloseableResource<T> - Class in alluxio.resource
A CloseableResource<T> is a wrapper around a resource of type T which must do some sort of cleanup when it is no longer in use.
CloseableResource(T) - Constructor for class alluxio.resource.CloseableResource
Creates a CloseableResource wrapper around the given resource.
CloseableSupplier<T extends Closeable> - Class in alluxio
Closeable supplier which supports lazy initialization and cleanup if initialized.
CloseableSupplier(Supplier<T>) - Constructor for class alluxio.CloseableSupplier
 
closeAndRethrow(Closer, Throwable) - Static method in class alluxio.util.CommonUtils
Closes the Closer and re-throws the Throwable.
closeAndRethrowRuntimeException(Closer, Throwable) - Static method in class alluxio.util.CommonUtils
closeChannel(Channel) - Static method in class alluxio.util.CommonUtils
Closes the netty channel from outside the netty I/O thread.
CLOSED_FS_ERROR_MESSAGE - Static variable in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
closeResource(BlockMasterClient) - Method in class alluxio.client.block.BlockMasterClientPool
 
closeResource(BlockWorkerClient) - Method in class alluxio.client.block.stream.BlockWorkerClientPool
 
closeResource(FileSystemMasterClient) - Method in class alluxio.client.file.FileSystemMasterClientPool
 
closeResource(Channel) - Method in class alluxio.network.netty.NettyChannelPool
 
closeResource() - Method in class alluxio.resource.CloseableResource
Performs any cleanup operations necessary when the resource is no longer in use.
closeResource(T) - Method in class alluxio.resource.DynamicResourcePool
Closes the resource.
closeResource() - Method in class alluxio.resource.PooledResource
 
closeResource() - Method in class alluxio.worker.block.BlockLock
 
closeStream() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
closeStream() - Method in class alluxio.fuse.file.FuseFileInStream
 
closeStream() - Method in class alluxio.fuse.file.FuseFileOutStream
 
closeStream() - Method in interface alluxio.fuse.file.FuseFileStream
Closes the stream without releasing the locking resource.
closeStream() - Method in class alluxio.fuse.file.FusePositionReader
 
closeStream() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
closeUfsBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Closes a UFS block for a client session.
CloudCostUtils - Class in alluxio.master.metrics
This class contains utilities to compute cloud cost savings.
CLUSTER - Static variable in class alluxio.metrics.MetricsSystem
 
CLUSTER_ACTIVE_RPC_READ_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ACTIVE_RPC_WRITE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DIRECT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_DEFAULT - Static variable in class alluxio.conf.Source
 
CLUSTER_FLAG - Static variable in class alluxio.stress.BaseParameters
 
CLUSTER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
CLUSTER_ID_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
CLUSTER_ID = 10;
CLUSTER_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
CLUSTER_LEADER_ID - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_LEADER_INDEX - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_LIMIT_FLAG - Static variable in class alluxio.stress.BaseParameters
 
CLUSTER_LOST_WORKERS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_START_DELAY_FLAG - Static variable in class alluxio.stress.BaseParameters
 
CLUSTER_WORKERS - Static variable in class alluxio.metrics.MetricKey
 
ClusterConfConsistencyValidationTask - Class in alluxio.cli
Task for validating Alluxio configuration consistency in the cluster.
ClusterConfConsistencyValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.ClusterConfConsistencyValidationTask
Creates a new instance of ClusterConfConsistencyValidationTask for validating Alluxio configuration consistency in the cluster.
CLUSTERCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigHashPResponse
 
CLUSTERCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
CLUSTERCONFIGLASTUPDATETIME_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
CLUSTERCONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
ClusterCounterKey(MetricsSystem.InstanceType, String) - Constructor for class alluxio.master.metrics.MetricsStore.ClusterCounterKey
clusterDefaultsLoaded() - Method in interface alluxio.conf.AlluxioConfiguration
 
clusterDefaultsLoaded() - Method in class alluxio.conf.InstancedConfiguration
 
clusterDefaultsLoaded() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
CLUSTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
CmdConfig - Interface in alluxio.job
A Cmd configuration.
CMDCONFIG_FIELD_NUMBER - Static variable in class alluxio.grpc.SubmitRequest
 
CmdInfo - Class in alluxio.master.job.common
A class representation for Command Information.
CmdInfo(long, OperationType, JobSource, long, List<String>) - Constructor for class alluxio.master.job.common.CmdInfo
Constructor for CmdInfo class.
CmdJobTracker - Class in alluxio.master.job.tracker
CmdJobTracker to schedule a Cmd job to run.
CmdJobTracker(FileSystemContext, JobMaster) - Constructor for class alluxio.master.job.tracker.CmdJobTracker
Create a new instance of CmdJobTracker.
CmdJobTracker(FileSystemContext, MigrateCliRunner, PersistRunner) - Constructor for class alluxio.master.job.tracker.CmdJobTracker
Constructor with runner providers.
CmdProgress - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CmdProgress
CmdProgress.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CmdProgress
CMDPROGRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
CmdProgressOrBuilder - Interface in alluxio.grpc
 
CmdRunAttempt - Class in alluxio.master.job.tracker
class for handling submission for a child job within a distributed command.
CmdRunAttempt(RetryPolicy, JobMaster) - Constructor for class alluxio.master.job.tracker.CmdRunAttempt
 
CMDSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusResponse
 
CmdStatusBlock - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CmdStatusBlock
CmdStatusBlock - Class in alluxio.job.wire
This class holds command status detailed information.
CmdStatusBlock(long, OperationType) - Constructor for class alluxio.job.wire.CmdStatusBlock
Constructor.
CmdStatusBlock(long, List<SimpleJobStatusBlock>, OperationType) - Constructor for class alluxio.job.wire.CmdStatusBlock
Constructor.
CmdStatusBlock.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CmdStatusBlock
CMDSTATUSBLOCK_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusDetailedResponse
 
CmdStatusBlockOrBuilder - Interface in alluxio.grpc
 
CmdSummary - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CmdSummary
CmdSummary.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.CmdSummary
CmdSummaryOrBuilder - Interface in alluxio.grpc
 
CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockStatus
 
CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileFailure
 
CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileFailure
 
CODE_FIELD_NUMBER - Static variable in class alluxio.grpc.RouteFailure
 
COL_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsInfo
 
COL_NAMES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
COL_NAMES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
COL_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsInfo
 
collect(String[]) - Method in class alluxio.cli.bundler.CollectInfo
Execute the shell and generate a tarball.
COLLECT_ON_EXIT - Static variable in class alluxio.ProcessUtils
 
collectAllFutures(List<CompletableFuture<T>>) - Static method in class alluxio.cli.bundler.CollectInfo
Waits for ALL futures to complete and returns a list of results.
CollectAlluxioInfoCommand - Class in alluxio.cli.bundler.command
Command to run a set of Alluxio commands.
CollectAlluxioInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
Creates a new instance of CollectAlluxioInfoCommand.
CollectAlluxioInfoCommand.AlluxioCommand - Class in alluxio.cli.bundler.command
A special shell command that runs an Alluxio cmdline operation.
CollectConfigCommand - Class in alluxio.cli.bundler.command
Command to collect Alluxio config files.
CollectConfigCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectConfigCommand
Creates a new instance of CollectConfigCommand.
CollectEnvCommand - Class in alluxio.cli.bundler.command
Command to run a set of bash commands to get system information.
CollectEnvCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectEnvCommand
Creates a new instance of CollectEnvCommand.
collectErrorsFromAllNodes() - Method in class alluxio.stress.common.GeneralBenchSummary
 
CollectInfo - Class in alluxio.cli.bundler
Class for collecting various information about all nodes in the cluster.
CollectInfo(AlluxioConfiguration) - Constructor for class alluxio.cli.bundler.CollectInfo
Creates a new instance of CollectInfo.
CollectJvmInfoCommand - Class in alluxio.cli.bundler.command
Command that collects information about the JVMs.
CollectJvmInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectJvmInfoCommand
Creates an instance of CollectJvmInfoCommand.
CollectLogCommand - Class in alluxio.cli.bundler.command
Command to collect Alluxio logs.
CollectLogCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectLogCommand
Creates a new instance of CollectLogCommand.
CollectMetricsCommand - Class in alluxio.cli.bundler.command
Command to probe Alluxio metrics for a few times.
CollectMetricsCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.CollectMetricsCommand
Creates a new instance of CollectMetricsCommand.
COLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Schema
 
COLUMN_CONSTRAINTS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Constraint
 
COLUMN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FileStatistics
 
COLUMN_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.SortingColumn
 
ColumnStatisticsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ColumnStatisticsData
ColumnStatisticsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ColumnStatisticsData
ColumnStatisticsData.DataCase - Enum in alluxio.grpc.table
 
ColumnStatisticsDataOrBuilder - Interface in alluxio.grpc.table
 
ColumnStatisticsInfo - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ColumnStatisticsInfo
ColumnStatisticsInfo.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ColumnStatisticsInfo
ColumnStatisticsInfoOrBuilder - Interface in alluxio.grpc.table
 
ColumnStatisticsList - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ColumnStatisticsList
ColumnStatisticsList.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ColumnStatisticsList
ColumnStatisticsListOrBuilder - Interface in alluxio.grpc.table
 
combine(Scope, Scope) - Static method in class alluxio.grpc.GrpcUtils
 
combineData(DataMessage<T, DataBuffer>) - Method in class alluxio.grpc.DataMessageMarshaller
Combines the data buffer into the message.
combineData(DataMessage<ReadResponse, DataBuffer>) - Method in class alluxio.grpc.ReadResponseMarshaller
 
combineData(DataMessage<WriteRequest, DataBuffer>) - Method in class alluxio.grpc.WriteRequestMarshaller
 
Command - Interface in alluxio.cli
An interface for all the commands that can be run from a shell.
Command - Class in alluxio.grpc
Protobuf type alluxio.grpc.Command
Command.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.Command
COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPResponse
 
COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemHeartbeatPResponse
 
COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterHeartbeatPResponse
 
COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterHeartbeatPResponse
 
COMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequest
 
COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
 
COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectConfigCommand
 
COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectEnvCommand
 
COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectJvmInfoCommand
 
COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
 
COMMAND_NAME - Static variable in class alluxio.cli.bundler.command.CollectMetricsCommand
 
CommandHandlingExecutor - Class in alluxio.worker.job.command
Manages the communication with the master.
CommandHandlingExecutor(JobServerContext, TaskExecutorManager, JobMasterClient, WorkerNetAddress) - Constructor for class alluxio.worker.job.command.CommandHandlingExecutor
Creates a new instance of CommandHandlingExecutor.
CommandManager - Class in alluxio.master.job.command
A command manager that manages the commands to issue to the workers.
CommandManager() - Constructor for class alluxio.master.job.command.CommandManager
Constructs a new CommandManager.
COMMANDOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemCommand
 
CommandOrBuilder - Interface in alluxio.grpc
 
CommandReturn - Class in alluxio.shell
Object representation of a command execution.
CommandReturn(int, String) - Constructor for class alluxio.shell.CommandReturn
Creates object from the contents.
CommandReturn(int, String[], String) - Constructor for class alluxio.shell.CommandReturn
Creates object from the contents.
COMMANDS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobHeartbeatPResponse
 
CommandType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.CommandType
CommandType - Enum in alluxio.wire
Types for file system commands.
COMMANDTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.Command
 
COMMANDTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemCommand
 
CommandUtils - Class in alluxio.cli
Class for convenience methods used by instances of Command.
COMMENT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
COMMENT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FieldSchema
 
commit(String) - Method in interface alluxio.client.file.cache.PageStore
Commit a temporary file.
commit(String, String) - Method in interface alluxio.client.file.cache.PageStore
Commit a temporary file with a new file ID.
commit(String, String) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
commit(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
Commit a temporary file.
commit(String, String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
Commit a temporary file with a new file ID.
commit() - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
Performs the batched write.
commit() - Method in class alluxio.security.login.AlluxioLoginModule
Commits the authentication (second phase).
commit() - Method in class alluxio.security.login.AppLoginModule
Commits the authentication (second phase).
commitBlock(CommitBlockPRequest, StreamObserver<CommitBlockPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
Marks the given block as committed.
commitBlock(CommitBlockPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
Marks the given block as committed.
commitBlock(CommitBlockPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
Marks the given block as committed.
commitBlock(CommitBlockPRequest, StreamObserver<CommitBlockPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Marks the given block as committed.
commitBlock(long, long, String, String, long, long) - Method in interface alluxio.master.block.BlockMaster
Marks a block as committed on a specific worker.
commitBlock(CommitBlockPRequest, StreamObserver<CommitBlockPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
commitBlock(long, long, String, String, long, long) - Method in class alluxio.master.block.DefaultBlockMaster
 
commitBlock(long, long, String, String, long, long) - Method in class alluxio.worker.block.BlockMasterClient
Commits a block on a worker.
commitBlock(long, long, boolean) - Method in interface alluxio.worker.block.BlockStore
Commits a block to Alluxio managed space.
commitBlock(long, long, boolean) - Method in interface alluxio.worker.block.BlockWorker
Commits a block to Alluxio managed space.
commitBlockInUFS(long, long) - Method in interface alluxio.master.block.BlockMaster
Marks a block as committed, but without a worker location.
commitBlockInUFS(long, long, JournalContext) - Method in interface alluxio.master.block.BlockMaster
Marks a block as committed, but without a worker location.
commitBlockInUFS(long, long, JournalContext) - Method in class alluxio.master.block.DefaultBlockMaster
 
CommitBlockPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockPOptions
CommitBlockPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockPOptions
CommitBlockPOptionsOrBuilder - Interface in alluxio.grpc
 
CommitBlockPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockPRequest
CommitBlockPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockPRequest
CommitBlockPRequestOrBuilder - Interface in alluxio.grpc
 
CommitBlockPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockPResponse
CommitBlockPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CommitBlockPResponse
CommitBlockPResponseOrBuilder - Interface in alluxio.grpc
 
commitFile(String) - Method in interface alluxio.client.file.cache.CacheManager
Commit the File.
commitFile(String) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
commitFile(String, String) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
commitFile(String) - Method in class alluxio.client.file.cache.LocalCacheManager
 
commitFile(String) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
commitFile(String, String) - Method in interface alluxio.client.file.cache.PageMetaStore
Commits a temp file so that all its pages become permanent.
commitFile() - Method in class alluxio.worker.block.io.BlockWriter
Commit the file.
commitFile() - Method in class alluxio.worker.dora.PagedFileWriter
 
COMMON_SSH_OPTS - Static variable in class alluxio.util.ShellUtils
Common shell OPTS to prevent stalling.
commonDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
commonDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckAccessPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckConsistencyPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ExistsPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.UnmountPOptions
 
COMMONOPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
commonPool() - Static method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the common pool instance.
CommonProto - Class in alluxio.grpc
 
CommonUtils - Class in alluxio.util
Common utilities shared by all components in Alluxio.
CommonUtils.ProcessType - Enum in alluxio.util
Alluxio process types.
compare(URIStatus, URIStatus) - Method in class alluxio.proxy.s3.S3RestUtils.URIStatusNameComparator
 
compare(String, String) - Static method in class alluxio.util.URIUtils
 
compare(WorkerInfo, WorkerInfo) - Method in class alluxio.wire.WorkerInfo.LastContactSecComparator
 
COMPARE_CHECK_FILES - Static variable in class alluxio.cli.fs.command.ConsistentHashCommand
 
compareAndSetForkJoinTaskTag(short, short) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Atomically conditionally sets the tag value for this task.
compareAndSetPendingCount(int, int) - Method in class alluxio.concurrent.jsr.CountedCompleter
Sets (atomically) the pending count to the given count only if it currently holds the given expected value.
compareAndSetServerConfigReference(InstancedConfiguration, InstancedConfiguration) - Static method in class alluxio.conf.Configuration
Compares and swap the two conf.
compareTierNames(String, String) - Static method in class alluxio.cli.fsadmin.FileSystemAdminShellUtils
Compares two tier names according to their rank values.
compareTo(AlluxioURI) - Method in class alluxio.AlluxioURI
 
compareTo(PropertyKey) - Method in class alluxio.conf.PropertyKey
 
compareTo(Source) - Method in class alluxio.conf.Source
 
compareTo(PlanInfo) - Method in class alluxio.job.plan.meta.PlanInfo
This method orders jobs using the time their status was last modified.
compareTo(Version) - Method in class alluxio.master.backcompat.Version
 
compareTo(InodeView) - Method in interface alluxio.master.file.meta.InodeView
 
compareTo(TtlBucket) - Method in class alluxio.master.file.meta.TtlBucket
Compares this bucket's TTL interval start time to that of another bucket.
compareTo(Task) - Method in class alluxio.master.job.CopyJob.CopyTask
 
compareTo(UfsJournalFile) - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
compareTo(Interval) - Method in class alluxio.master.predicate.interval.Interval
 
compareTo(MetricKey) - Method in class alluxio.metrics.MetricKey
 
compareTo(Task) - Method in class alluxio.scheduler.job.Task
 
compareTo(Authority) - Method in interface alluxio.uri.Authority
 
compareTo(Authority) - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
compareTo(Authority) - Method in class alluxio.uri.MultiMasterAuthority
 
compareTo(URI) - Method in class alluxio.uri.StandardURI
 
compareTo(Authority) - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
compareTo(NodeInfo) - Method in class alluxio.util.webui.NodeInfo
Compare NodeInfo by lexicographical order of their associated host.
compareVersion(String, String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Compares two version.
CompletableFuture<T> - Class in alluxio.concurrent.jsr
A Future that may be explicitly completed (setting its value and status), and may be used as a CompletionStage, supporting dependent functions and actions that trigger upon its completion.
CompletableFuture() - Constructor for class alluxio.concurrent.jsr.CompletableFuture
Creates a new incomplete CompletableFuture.
CompletableFuture.AsynchronousCompletionTask - Interface in alluxio.concurrent.jsr
A marker interface identifying asynchronous tasks produced by async methods.
complete(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
If not already completed, sets the value returned by CompletableFuture.get() and related methods to the given value.
complete(T) - Method in class alluxio.concurrent.jsr.CountedCompleter
Regardless of pending count, invokes CountedCompleter.onCompletion(CountedCompleter), marks this task as complete and further triggers CountedCompleter.tryComplete() on this task's completer, if one exists.
complete(V) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Completes this task, and if not already aborted or cancelled, returning the given value as the result of subsequent invocations of join and related operations.
complete() - Method in class alluxio.master.file.ListStatusPartialResultStream
Called once the listing is complete, and sends the response to the client.
complete() - Method in class alluxio.master.file.ListStatusResultStream
Used to complete the stream.
complete() - Method in interface alluxio.underfs.MultipartUploader
Complete a multipart upload.
COMPLETE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
completeAsync(Supplier<? extends T>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
Completes this CompletableFuture with the result of the given Supplier function invoked from an asynchronous task using the given executor.
completeAsync(Supplier<? extends T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
Completes this CompletableFuture with the result of the given Supplier function invoked from an asynchronous task using the default executor.
completeCurrentLog() - Method in interface alluxio.master.journalv0.JournalWriter
Marks the current log as completed.
completeCurrentLog() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
completed() - Static method in class alluxio.master.journal.CatchupFuture
 
COMPLETED_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
COMPLETED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
COMPLETED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
Completed_VALUE - Static variable in enum alluxio.grpc.BackupState
Completed = 5;
COMPLETED_VALUE - Static variable in enum alluxio.grpc.Status
COMPLETED = 5;
completedFuture(U) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is already completed with the given value.
completedStage(U) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletionStage that is already completed with the given value and supports only those methods in interface CompletionStage.
completeExceptionally(Throwable) - Method in class alluxio.concurrent.jsr.CompletableFuture
If not already completed, causes invocations of CompletableFuture.get() and related methods to throw the given exception.
completeExceptionally(Throwable) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Completes this task abnormally, and if not already aborted or cancelled, causes it to throw the given exception upon join and related operations.
completeExceptionally(Exception) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
Creates a future that is completed exceptionally.
completeFile(CompleteFilePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Complete a file when writing is done.
completeFile(CompleteFilePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
completeFile(String, CompleteFilePOptions, String) - Method in class alluxio.client.file.dora.DoraCacheClient
Mark the newly created and written file as complete.
completeFile(AlluxioURI, CompleteFilePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Marks a file as completed.
completeFile(AlluxioURI, CompleteFilePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Marks a file as completed.
completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Marks a file as completed.
completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Marks a file as completed.
completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Marks a file as completed.
completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Marks a file as completed.
completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Marks a file as completed.
completeFile(CompleteFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Marks a file as completed.
completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Marks a file as completed.
completeFile(AlluxioURI, CompleteFileContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
completeFile(AlluxioURI, CompleteFileContext) - Method in interface alluxio.master.file.FileSystemMaster
Completes a file.
completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
completeFile(String, CompleteFilePOptions, String) - Method in interface alluxio.worker.dora.DoraWorker
Complete writing a file.
completeFile(String, CompleteFilePOptions, String) - Method in class alluxio.worker.dora.PagedDoraWorker
 
completeFile(CompleteFilePRequest, StreamObserver<CompleteFilePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
CompleteFileContext - Class in alluxio.master.file.contexts
Used to merge and wrap CompleteFilePOptions.
completeFileDefaults() - Static method in class alluxio.master.file.FileSystemMasterOptions
 
CompleteFilePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CompleteFilePOptions
CompleteFilePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CompleteFilePOptions
CompleteFilePOptionsOrBuilder - Interface in alluxio.grpc
 
CompleteFilePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CompleteFilePRequest
CompleteFilePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CompleteFilePRequest
CompleteFilePRequestOrBuilder - Interface in alluxio.grpc
 
CompleteFilePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CompleteFilePResponse
CompleteFilePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CompleteFilePResponse
CompleteFilePResponseOrBuilder - Interface in alluxio.grpc
 
completeLogs() - Method in interface alluxio.master.journalv0.JournalWriter
Marks all logs as completed.
completeLogs() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
CompleteMultipartUploadHandler - Class in alluxio.proxy.s3
A handler process multipart upload complete response.
CompleteMultipartUploadHandler(FileSystem, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadHandler
Creates a new instance of CompleteMultipartUploadHandler.
CompleteMultipartUploadHandler.CompleteMultipartUploadTask - Class in alluxio.proxy.s3
Complete Multipart upload Task.
completeMultipartUploadInternal() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
completeMultiPartUploadInternal() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
completeMultipartUploadInternal() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
completeMultiPartUploadInternal() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
completeMultipartUploadInternal() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
completeMultiPartUploadInternal() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
completeMultipartUploadInternal() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
completeMultiPartUploadInternal() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
completeMultipartUploadInternal() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
CompleteMultipartUploadRequest - Class in alluxio.proxy.s3
Implementation of CompleteMultipartUploadRequest according to https://docs.aws.amazon.com/AmazonS3/latest/API/API_ListMultipartUploads.html.
CompleteMultipartUploadRequest() - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest
CompleteMultipartUploadRequest(List<CompleteMultipartUploadRequest.Part>) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest
CompleteMultipartUploadRequest(List<CompleteMultipartUploadRequest.Part>, boolean) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest
Deprecated.
always ignore valdateion
CompleteMultipartUploadRequest.Part - Class in alluxio.proxy.s3
The Part POJO.
CompleteMultipartUploadResult - Class in alluxio.proxy.s3
Result returned after requests for completing a multipart upload.
CompleteMultipartUploadResult() - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
Constructs an CompleteMultipartUploadResult with fields initialized to empty strings.
CompleteMultipartUploadResult(String, String, String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
Constructs an CompleteMultipartUploadResult with the specified values.
CompleteMultipartUploadResult(String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadResult
Constructs an CompleteMultipartUploadResult with the specified values.
CompleteMultipartUploadTask(FileSystem, FileSystem, String, String, String, String) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
CompleteMultipartUploadTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
Create a CompleteMultipartUploadTask.
completeOnTimeout(T, long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
Completes this CompletableFuture with the given value if not otherwise completed before the given timeout.
completeRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
completeRequest(BlockWriteRequestContext, Channel) - Method in class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
 
completeRequest(UfsFileWriteRequestContext, Channel) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
CompletionStage<T> - Interface in alluxio.concurrent.jsr
A stage of a possibly asynchronous computation, that performs an action or computes a value when another CompletionStage completes.
CompositeConfig - Class in alluxio.job.workflow.composite
A composite job is a list of jobs to be executed either sequentially or concurrently.
CompositeConfig(ArrayList<JobConfig>, Boolean) - Constructor for class alluxio.job.workflow.composite.CompositeConfig
 
CompositeDataBuffer - Class in alluxio.network.protocol.databuffer
A CompositeDataBuffer which includes a List of DataBuffer.
CompositeDataBuffer(List<DataBuffer>) - Constructor for class alluxio.network.protocol.databuffer.CompositeDataBuffer
CompositeDataBuffer wraps multiple DataBuffer.
CompositeExecution - Class in alluxio.job.workflow.composite
Job execution for CompositeConfig.
CompositeExecution(CompositeConfig) - Constructor for class alluxio.job.workflow.composite.CompositeExecution
Default constructor.
CompositeExecutionFactory - Class in alluxio.job.workflow.composite
The factory for generating CompositeExecution from CompositeConfig.
CompositeExecutionFactory() - Constructor for class alluxio.job.workflow.composite.CompositeExecutionFactory
 
CompositeInodeLockList - Class in alluxio.master.file.meta
Manages the locks for a list of inodes, based off an existing lock list.
CompositeInodeLockList(InodeLockList, boolean) - Constructor for class alluxio.master.file.meta.CompositeInodeLockList
Constructs a new lock list, using an existing lock list as the base list.
CompoundCheckpointFormat - Class in alluxio.master.journal.checkpoint
Format for compound checkpoints.
CompoundCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.CompoundCheckpointFormat
 
CompoundCheckpointFormat.CompoundCheckpointReader - Class in alluxio.master.journal.checkpoint
Reader for compound checkpoints.
CompoundCheckpointFormat.CompoundCheckpointReader.Entry - Class in alluxio.master.journal.checkpoint
A compound checkpoint entry.
CompoundCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader
 
compress(String, File...) - Static method in class alluxio.cli.bundler.TarUtils
Compresses a list of files to one destination.
compress(Path, OutputStream, int, int) - Static method in class alluxio.util.compression.ParallelZipUtils
Creates a zipped archive from the given path in parallel, streaming the data to the give output stream.
compute() - Method in class alluxio.concurrent.jsr.CountedCompleter
The main computation performed by this task.
computeNextWaitTime() - Method in class alluxio.retry.ExponentialTimeBoundedRetry
 
computeNextWaitTime() - Method in class alluxio.retry.TimeBoundedRetry
 
computeSyncPlan(Inode, Fingerprint, boolean) - Static method in class alluxio.master.file.meta.UfsSyncUtils
Given an inode and ufs status, returns a sync plan describing how to sync the inode with the ufs.
computeTimeData() - Method in class alluxio.stress.common.SummaryStatistics
 
concat(CloseableIterator<T>, CloseableIterator<T>) - Static method in class alluxio.resource.CloseableIterator
Combines two iterators into a single iterator.
concat(List<CloseableIterator<T>>) - Static method in class alluxio.resource.CloseableIterator
Concatenates iterators.
concatPath(Object, Object) - Static method in class alluxio.util.io.PathUtils
Joins two path elements, separated by AlluxioURI.SEPARATOR.
concatPath(Object, Object...) - Static method in class alluxio.util.io.PathUtils
Joins each element in paths in order, separated by AlluxioURI.SEPARATOR.
concatUfsPath(String, String) - Static method in class alluxio.util.io.PathUtils
Join two path elements for ufs, separated by AlluxioURI.SEPARATOR.
ConcurrentClockCuckooFilter<T> - Class in alluxio.client.file.cache.cuckoofilter
A concurrent cuckoo filter with three customized field: clock, size and scope.
ConcurrentHashSet<T> - Class in alluxio.collections
A concurrent hash set.
ConcurrentHashSet() - Constructor for class alluxio.collections.ConcurrentHashSet
Creates a new ConcurrentHashSet.
ConcurrentHashSet(int, float, int) - Constructor for class alluxio.collections.ConcurrentHashSet
Creates a new ConcurrentHashSet.
ConcurrentIdentityHashMap<K,V> - Class in alluxio.collections
An implementation ConcurrentHashMap that utilizes identity semantics with its keys Having identity semantics means that it is possible to have two objects with which are equal based on the object's equals() implementation, but not be overridden in the hash map if you try to put both.
ConcurrentIdentityHashMap() - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with the default initial table size (16).
ConcurrentIdentityHashMap(int) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with an initial table size accommodating the specified number of elements without having to dynamically resize.
ConcurrentIdentityHashMap(int, float) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity) and initial load factor (loadFactor) with a concurrencyLevel of 1.
ConcurrentIdentityHashMap(int, float, int) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity), load factor (loadFactor), and number of expected concurrently updating threads (concurrencyLevel).
concurrentReadPart() - Method in class alluxio.PositionReaderTest
Tests concurrently read from position reader.
CONF - Static variable in class alluxio.stress.worker.UfsIOParameters
 
CONF_DIR - Static variable in class alluxio.conf.PropertyKey
 
CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
CONF_REGEX - Static variable in class alluxio.conf.PropertyKey
Regex to find ${key} for variable substitution.
CONF_VALIDATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
CONF_VALIDATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
CONFIG_CHECKER_MULTI_MASTERS - Static variable in class alluxio.multi.process.PortCoordination
 
CONFIG_CHECKER_MULTI_MASTERS_EMBEDDED_HA - Static variable in class alluxio.multi.process.PortCoordination
 
CONFIG_CHECKER_MULTI_NODES - Static variable in class alluxio.multi.process.PortCoordination
 
CONFIG_CHECKER_MULTI_WORKERS - Static variable in class alluxio.multi.process.PortCoordination
 
CONFIG_CHECKER_UNSET_VS_SET - Static variable in class alluxio.multi.process.PortCoordination
 
ConfigCheckReport - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ConfigCheckReport
ConfigCheckReport - Class in alluxio.wire
Represents a configuration report which records the configuration checker results.
ConfigCheckReport() - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport.
ConfigCheckReport(Map<Scope, List<InconsistentProperty>>, Map<Scope, List<InconsistentProperty>>, ConfigStatus) - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport.
ConfigCheckReport(ConfigCheckReport) - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport from a proto representation.
ConfigCheckReport.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ConfigCheckReport
ConfigCheckReportOrBuilder - Interface in alluxio.grpc
 
ConfigHash - Class in alluxio.wire
Hashes of cluster and path level configurations.
ConfigHash(String, String, long, long) - Constructor for class alluxio.wire.ConfigHash
Constructs a new ConfigHash.
ConfigHashSync - Class in alluxio.client.file
Heartbeat task for getting the latest configuration versions from meta master, if versions change, then re-initialize the filesystem context.
ConfigHashSync(FileSystemContext) - Constructor for class alluxio.client.file.ConfigHashSync
Constructs a new ConfigHashSync.
ConfigProperties - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ConfigProperties
ConfigProperties.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ConfigProperties
ConfigPropertiesOrBuilder - Interface in alluxio.grpc
 
ConfigProperty - Class in alluxio.grpc
Protobuf type alluxio.grpc.ConfigProperty
ConfigProperty.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.ConfigProperty
ConfigPropertyOrBuilder - Interface in alluxio.grpc
 
ConfigRecord - Class in alluxio.master.meta.checkconf
An Alluxio configuration record.
ConfigRecord() - Constructor for class alluxio.master.meta.checkconf.ConfigRecord
Creates a new instance of ConfigRecord.
ConfigRecord(PropertyKey, String, String) - Constructor for class alluxio.master.meta.checkconf.ConfigRecord
Creates a new instance of ConfigRecord.
CONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPOptions
 
CONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPOptions
 
ConfigStatus - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.meta.ConfigStatus
Configuration - Class in alluxio.conf
Global configuration properties of Alluxio.
Configuration - Class in alluxio.wire
Represents cluster level and path level configuration returned by meta master.
Configuration.Builder - Class in alluxio.wire
Configuration builder.
ConfigurationChecker - Class in alluxio.master.meta.checkconf
This class is responsible for checking server-side configuration.
ConfigurationChecker(ConfigurationStore, ConfigurationStore) - Constructor for class alluxio.master.meta.checkconf.ConfigurationChecker
Constructs a new ConfigurationChecker.
ConfigurationCommand - Class in alluxio.cli.fsadmin.doctor
Prints server-side configuration errors and warnings.
ConfigurationCommand(MetaMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.doctor.ConfigurationCommand
Creates a new instance of ConfigurationCommand.
ConfigurationDocGenerator - Class in alluxio.cli.docgen
CSV_FILE_DIR utility to generate property keys to csv files.
ConfigurationStore - Class in alluxio.master.meta.checkconf
This class is responsible for recording server-side configuration.
ConfigurationStore() - Constructor for class alluxio.master.meta.checkconf.ConfigurationStore
Constructs a new ConfigurationStore.
ConfigurationUtils - Class in alluxio.util
Utilities for working with Alluxio configurations.
ConfigurationValueOptions - Class in alluxio.conf
Options for getting configuration values.
configure() - Method in class alluxio.worker.modules.AlluxioWorkerProcessModule
 
configure() - Method in class alluxio.worker.modules.DoraWorkerModule
 
configure() - Method in class alluxio.worker.modules.GrpcServerModule
 
configure() - Method in class alluxio.worker.modules.NettyServerModule
 
connect() - Method in class alluxio.AbstractClient
Connects with the remote.
connect() - Method in interface alluxio.Client
Connects with the remote.
connect(StreamObserver<TransportMessage>) - Method in interface alluxio.grpc.MessagingServiceGrpc.AsyncService
 
connect(StreamObserver<TransportMessage>) - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceStub
 
connect() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
 
connect(InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingClient
Creates a client and connects to the given address.
connect(StreamObserver<TransportMessage>) - Method in class alluxio.master.transport.GrpcMessagingServiceClientHandler
RPC for establishing bi-di stream between client/server.
connectFromMaster(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
connectFromMaster(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
connectFromMaster(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
connectFromMaster(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
connectFromMaster(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
connectFromMaster(String) - Method in interface alluxio.underfs.UnderFileSystem
Takes any necessary actions required to establish a connection to the under file system from the given master host e.g.
connectFromMaster(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
connectFromWorker(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
connectFromWorker(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
connectFromWorker(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
connectFromWorker(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
connectFromWorker(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
connectFromWorker(String) - Method in interface alluxio.underfs.UnderFileSystem
Takes any necessary actions required to establish a connection to the under file system from the given worker host e.g.
connectFromWorker(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
ConnectionFailedException - Exception in alluxio.exception
Exception used when a network connection failure occurs.
ConnectionFailedException(String) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified detail message.
ConnectionFailedException(String, Throwable) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified detail message and cause.
ConnectionFailedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified exception message and multiple parameters.
ConnectionFailedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
connectUfs(UnderFileSystem) - Method in class alluxio.master.NoopUfsManager
 
connectUfs(UnderFileSystem) - Method in class alluxio.underfs.AbstractUfsManager
Takes any necessary actions required to establish a connection to the under file system.
connectUfs(UnderFileSystem) - Method in class alluxio.underfs.JobUfsManager
 
connectUfs(UnderFileSystem) - Method in class alluxio.underfs.MasterUfsManager
 
connectUfs(UnderFileSystem) - Method in class alluxio.underfs.WorkerUfsManager
 
connectUfs(UnderFileSystem) - Method in class alluxio.worker.dora.DoraUfsManager
 
connectWithRuntimeException() - Method in class alluxio.AbstractClient
Connects with the remote server.
ConsistentHashCommand - Class in alluxio.cli.fs.command
Copies the specified file specified by "source path" to the path specified by "remote path".
ConsistentHashCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.ConsistentHashCommand
 
ConsistentHashPolicy - Class in alluxio.client.file.dora
An impl of WorkerLocationPolicy.
ConsistentHashPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.file.dora.ConsistentHashPolicy
Constructs a new ConsistentHashPolicy.
ConsistentHashProvider - Class in alluxio.client.file.dora
A consistent hashing algorithm implementation.
ConsistentHashProvider(int, long) - Constructor for class alluxio.client.file.dora.ConsistentHashProvider
Constructor.
ConsistentUnderFileSystem - Class in alluxio.underfs
Represents a consistent under filesystem which does not have eventual consistency issues.
ConsistentUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.ConsistentUnderFileSystem
Creates a new ConsistentUnderFileSystem for the given uri.
ConsoleSink - Class in alluxio.metrics.sink
A sink which outputs metric values to the console.
ConsoleSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.ConsoleSink
Creates a new ConsoleSink with a Properties and MetricRegistry.
constantExecutorServiceFactory(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceFactories
 
Constants - Class in alluxio
System wide constants.
Constraint - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Constraint
Constraint.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Constraint
CONSTRAINT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ReadTablePRequest
 
ConstraintOrBuilder - Interface in alluxio.grpc.table
 
CONTAINER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
CONTAINERHOST_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
 
ContainerIdGenerable - Interface in alluxio.master.block
Provides generation of container IDs.
contains(Object) - Method in class alluxio.collections.ConcurrentHashSet
 
contains(Object) - Method in class alluxio.collections.DelegatingSet
 
contains(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Checks if a node with the given payload is in the DAG.
contains(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Whether there is an object with the specified index field value in the set.
contains(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
contains(Scope, Scope) - Static method in class alluxio.grpc.GrpcUtils
 
contains(AclAction) - Method in class alluxio.security.authorization.AclActions
 
containsAddedBlocksOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
containsAddedBlocksOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
containsAddedBlocksOnTiers(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
containsAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
containsAll(Collection<?>) - Method in class alluxio.collections.DelegatingSet
 
containsAll(Collection<?>) - Method in class alluxio.collections.UnmodifiableArrayList
 
containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
map<string, int64> capacityBytesOnTiers = 2;
containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions
map<string, int64> capacityBytesOnTiers = 2;
containsCapacityBytesOnTiers(String) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> capacityBytesOnTiers = 2;
containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> capacityBytesOnTiers = 2;
containsCapacityBytesOnTiers(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> capacityBytesOnTiers = 8;
containsCapacityBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo
map<string, int64> capacityBytesOnTiers = 8;
containsCapacityBytesOnTiers(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 8;
containsColumn(String) - Method in class alluxio.grpc.table.FileStatistics.Builder
map column names to column statistics
containsColumn(String) - Method in class alluxio.grpc.table.FileStatistics
map column names to column statistics
containsColumn(String) - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
map column names to column statistics
containsColumnConstraints(String) - Method in class alluxio.grpc.table.Constraint.Builder
maps column to constraint, columns not present are not constrained
containsColumnConstraints(String) - Method in class alluxio.grpc.table.Constraint
maps column to constraint, columns not present are not constrained
containsColumnConstraints(String) - Method in interface alluxio.grpc.table.ConstraintOrBuilder
maps column to constraint, columns not present are not constrained
containsCreate(int) - Static method in class alluxio.fuse.AlluxioFuseOpenUtils
Checks if the open flag contains create open flag.
containsCurrentBlocksOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
containsCurrentBlocksOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
containsCurrentBlocksOnTiers(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
containsErrors(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
containsErrors(String) - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
containsErrors(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
containsErrors(String) - Method in class alluxio.grpc.PolicyStatus.Builder
map<string, string> errors = 10;
containsErrors(String) - Method in class alluxio.grpc.PolicyStatus
map<string, string> errors = 10;
containsErrors(String) - Method in interface alluxio.grpc.PolicyStatusOrBuilder
map<string, string> errors = 10;
containsField(V) - Method in interface alluxio.collections.FieldIndex
Returns whether there is an object with the specified index field value in the set.
containsField(V) - Method in class alluxio.collections.NonUniqueFieldIndex
 
containsField(V) - Method in class alluxio.collections.UniqueFieldIndex
 
containsInterruptedException(Throwable) - Static method in class alluxio.util.ExceptionUtils
 
containsKey(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
containsKey(K) - Method in class alluxio.collections.LockPool
Returns whether the pool contains a particular key.
containsLocalIp(List<InetSocketAddress>, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
 
containsLostStorage(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of lost storage paths on all tiers
containsLostStorage(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of lost storage paths on all tiers
containsLostStorage(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of lost storage paths on all tiers
containsLostStorage(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of tier alias to a list of lost storage paths.
containsLostStorage(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of tier alias to a list of lost storage paths.
containsLostStorage(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of tier alias to a list of lost storage paths.
containsLostStorage(String) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
a map from tier alias to the lost storage paths
containsLostStorage(String) - Method in class alluxio.grpc.WorkerLostStorageInfo
a map from tier alias to the lost storage paths
containsLostStorage(String) - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
a map from tier alias to the lost storage paths
containsMetrics(String) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
containsMetrics(String) - Method in class alluxio.grpc.GetMetricsPResponse
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
containsMetrics(String) - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
containsMountPoint(AlluxioURI, boolean) - Method in class alluxio.master.file.meta.MountTable
 
containsMountPoints(String) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
containsMountPoints(String) - Method in class alluxio.grpc.GetMountTablePResponse
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
containsMountPoints(String) - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
containsObject(T) - Method in interface alluxio.collections.FieldIndex
Returns whether there is an object in the set.
containsObject(T) - Method in class alluxio.collections.NonUniqueFieldIndex
 
containsObject(T) - Method in class alluxio.collections.UniqueFieldIndex
 
containsOptions(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
containsOptions(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest
map<string, string> options = 5;
containsOptions(String) - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
map<string, string> options = 5;
containsParameter(String) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
containsParameter(String) - Method in class alluxio.grpc.table.Database
map<string, string> parameter = 4;
containsParameter(String) - Method in interface alluxio.grpc.table.DatabaseOrBuilder
map<string, string> parameter = 4;
containsParameters(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
map<string, string> parameters = 7;
containsParameters(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
map<string, string> parameters = 7;
containsParameters(String) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
map<string, string> parameters = 7;
containsParameters(String) - Method in class alluxio.grpc.table.TableInfo.Builder
map<string, string> parameters = 7;
containsParameters(String) - Method in class alluxio.grpc.table.TableInfo
map<string, string> parameters = 7;
containsParameters(String) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
map<string, string> parameters = 7;
containsPartitionStatistics(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
containsPartitionStatistics(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
containsPartitionStatistics(String) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
containsPathConfigs(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
containsPathConfigs(String) - Method in class alluxio.grpc.GetConfigurationPResponse
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
containsPathConfigs(String) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
containsProperties(String) - Method in class alluxio.grpc.MountPointInfo.Builder
map<string, string> properties = 6;
containsProperties(String) - Method in class alluxio.grpc.MountPointInfo
map<string, string> properties = 6;
containsProperties(String) - Method in interface alluxio.grpc.MountPointInfoOrBuilder
map<string, string> properties = 6;
containsProperties(String) - Method in class alluxio.grpc.MountPOptions.Builder
map<string, string> properties = 2;
containsProperties(String) - Method in class alluxio.grpc.MountPOptions
map<string, string> properties = 2;
containsProperties(String) - Method in interface alluxio.grpc.MountPOptionsOrBuilder
map<string, string> properties = 2;
containsProperties(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
map<string, string> properties = 2;
containsProperties(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest
map<string, string> properties = 2;
containsProperties(String) - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
map<string, string> properties = 2;
containsProperties(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
map<string, string> properties = 1;
containsProperties(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest
map<string, string> properties = 1;
containsProperties(String) - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
map<string, string> properties = 1;
containsProperties(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
map<string, string> properties = 2;
containsProperties(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
map<string, string> properties = 2;
containsProperties(String) - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
map<string, string> properties = 2;
containsSerdelibParameters(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
map<string, string> serdelib_parameters = 4;
containsSerdelibParameters(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
map<string, string> serdelib_parameters = 4;
containsSerdelibParameters(String) - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
map<string, string> serdelib_parameters = 4;
containsSerdeParameters(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
map<string, string> serde_parameters = 5;
containsSerdeParameters(String) - Method in class alluxio.grpc.table.layout.hive.Storage
map<string, string> serde_parameters = 5;
containsSerdeParameters(String) - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
map<string, string> serde_parameters = 5;
containsStats(String) - Method in class alluxio.grpc.table.Layout.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
containsStats(String) - Method in class alluxio.grpc.table.Layout
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
containsStats(String) - Method in interface alluxio.grpc.table.LayoutOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
containsStatus(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
map<string, bool> status = 1;
containsStatus(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse
map<string, bool> status = 1;
containsStatus(String) - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
map<string, bool> status = 1;
containsTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
containsTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus
map<string, string> tables_errors = 1;
containsTablesErrors(String) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
map<string, string> tables_errors = 1;
containsTags(String) - Method in class alluxio.grpc.Metric.Builder
map<string, string> tags = 6;
containsTags(String) - Method in class alluxio.grpc.Metric
map<string, string> tags = 6;
containsTags(String) - Method in interface alluxio.grpc.MetricOrBuilder
map<string, string> tags = 6;
containsTotalBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
containsTotalBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of total bytes on each tier
containsTotalBytesOnTiers(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of total bytes on each tier
containsTruncate(int) - Static method in class alluxio.fuse.AlluxioFuseOpenUtils
Checks if the open flag contains truncate open flag.
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of space used in bytes on all tiers
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of space used in bytes on all tiers
containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of space used in bytes on all tiers
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> usedBytesOnTiers = 7;
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> usedBytesOnTiers = 7;
containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> usedBytesOnTiers = 7;
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of used bytes on each tier
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of used bytes on each tier
containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of used bytes on each tier
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> usedBytesOnTiers = 9;
containsUsedBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo
map<string, int64> usedBytesOnTiers = 9;
containsUsedBytesOnTiers(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> usedBytesOnTiers = 9;
containsValue(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
containsValues(String) - Method in class alluxio.grpc.InconsistentProperty.Builder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
containsValues(String) - Method in class alluxio.grpc.InconsistentProperty
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
containsValues(String) - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
containsWarns(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
containsWarns(String) - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
containsWarns(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
containsWildcard() - Method in class alluxio.AlluxioURI
Whether or not the AlluxioURI contains wildcard(s).
containsXattr(String) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
map<string, bytes> xattr = 6;
containsXattr(String) - Method in class alluxio.grpc.CreateDirectoryPOptions
map<string, bytes> xattr = 6;
containsXattr(String) - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
map<string, bytes> xattr = 6;
containsXattr(String) - Method in class alluxio.grpc.CreateFilePOptions.Builder
map<string, bytes> xattr = 11;
containsXattr(String) - Method in class alluxio.grpc.CreateFilePOptions
map<string, bytes> xattr = 11;
containsXattr(String) - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
map<string, bytes> xattr = 11;
containsXattr(String) - Method in class alluxio.grpc.FileInfo.Builder
map<string, bytes> xattr = 32;
containsXattr(String) - Method in class alluxio.grpc.FileInfo
map<string, bytes> xattr = 32;
containsXattr(String) - Method in interface alluxio.grpc.FileInfoOrBuilder
map<string, bytes> xattr = 32;
containsXattr(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
map<string, bytes> xattr = 11;
containsXattr(String) - Method in class alluxio.grpc.SetAttributePOptions
map<string, bytes> xattr = 11;
containsXattr(String) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
map<string, bytes> xattr = 11;
containsXattr(String) - Method in class alluxio.grpc.UfsStatus.Builder
map<string, bytes> xattr = 7;
containsXattr(String) - Method in class alluxio.grpc.UfsStatus
map<string, bytes> xattr = 7;
containsXattr(String) - Method in interface alluxio.grpc.UfsStatusOrBuilder
map<string, bytes> xattr = 7;
containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
map<string, bytes> xAttr = 19;
containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
map<string, bytes> xAttr = 19;
containsXAttr(String) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
map<string, bytes> xAttr = 19;
containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
map<string, bytes> xAttr = 28;
containsXAttr(String) - Method in class alluxio.proto.journal.File.InodeFileEntry
map<string, bytes> xAttr = 28;
containsXAttr(String) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
map<string, bytes> xAttr = 28;
containsXAttr(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
map<string, bytes> xAttr = 17;
containsXAttr(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
map<string, bytes> xAttr = 17;
containsXAttr(String) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
map<string, bytes> xAttr = 17;
containsXAttr(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Extended attributes, general purpose.
containsXAttr(String) - Method in class alluxio.proto.meta.InodeMeta.Inode
Extended attributes, general purpose.
containsXAttr(String) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Extended attributes, general purpose.
Content(String, String, String) - Constructor for class alluxio.s3.ListBucketResult.Content
Constructs a new ListBucketResult.Content.
Content(String, String, String, boolean) - Constructor for class alluxio.s3.ListBucketResult.Content
Constructs a new ListBucketResult.Content.
CONTENT_HASH_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsFileStatus
 
CONTENT_LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsFileStatus
 
CONTENT_TYPE_XATTR_KEY - Static variable in class alluxio.s3.S3Constants
 
CONTENTHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePOptions
 
CONTENTHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
CONTENTHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteResponse
 
ContentHashable - Interface in alluxio.underfs
Interface for returning the content hash.
Context - Class in alluxio.cli.fsadmin.command
Context for running an fsadmin command.
Context(FileSystemMasterClient, BlockMasterClient, MetaMasterClient, MetricsMasterClient, JournalMasterClient, JournalMasterClient, JobMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.command.Context
 
continueTask() - Method in class alluxio.proxy.s3.S3BaseTask
Run core S3 API logic from different S3 task.
continueTask() - Method in class alluxio.proxy.s3.S3BucketTask
 
continueTask() - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
 
continueTask() - Method in class alluxio.proxy.s3.S3ObjectTask
 
continueTask() - Method in class alluxio.worker.s3.S3NettyBaseTask
Run core S3 API logic from different S3 task.
continueTask() - Method in class alluxio.worker.s3.S3NettyBucketTask
 
continueTask() - Method in class alluxio.worker.s3.S3NettyObjectTask
 
ControllableQueue<T> - Class in alluxio.util.executor
A controllable queue is a priority queue with ControllableQueue.DelayNodes.
ControllableQueue() - Constructor for class alluxio.util.executor.ControllableQueue
Constructs a new ControllableQueue.
ControllableQueue.DelayNode<T> - Class in alluxio.util.executor
A delay node in delta queue which records the value and the total delay (which is the original delay plus the past time).
ControllableScheduler - Class in alluxio.util.executor
A controllable scheduler supports jump to a future time and run all commands within that time period.
ControllableScheduler() - Constructor for class alluxio.util.executor.ControllableScheduler
 
convert(String) - Method in class alluxio.cli.TestRunner.WorkerAddressConverter
 
convert(String) - Method in class alluxio.stress.client.ClientIOParameters.ClientIOOperationConverter
 
convert(String) - Method in class alluxio.stress.common.FileSystemParameters.FileSystemParametersClientTypeConverter
 
convert(String) - Method in class alluxio.stress.common.FileSystemParameters.FileSystemParametersReadTypeConverter
 
convert(String) - Method in class alluxio.stress.common.FileSystemParameters.FileSystemParametersWriteTypeConverter
 
convertAclToStringEntries() - Method in class alluxio.wire.FileInfo
 
convertAddressToStringWebPort(WorkerNetAddress) - Static method in class alluxio.cli.fsadmin.command.WorkerAddressUtils
Converts a worker address to string.
convertAlluxioPathToUfsPath(AlluxioURI, AlluxioURI) - Static method in class alluxio.util.io.PathUtils
Converts the Alluxio based path to UfsBaseFileSystem based path if needed.
convertBlockListMapToProto(Map<BlockStoreLocation, List<Long>>) - Method in class alluxio.worker.block.BlockMasterClient
Converts the block list map to a proto list.
convertByteArrayToStringWithoutEscape(byte[], int, int) - Static method in class alluxio.util.webui.WebUtils
Converts a byte array to string.
convertDefaultAclToStringEntries() - Method in class alluxio.wire.FileInfo
 
convertFromByteString(Map<String, ByteString>) - Static method in class alluxio.util.CommonUtils
 
convertMsToClockTime(long) - Static method in class alluxio.util.CommonUtils
Converts milliseconds to clock time.
convertMsToDate(long, String) - Static method in class alluxio.util.CommonUtils
Converts a millisecond number to a formatted date String.
convertResults(List<ValidationTaskResult>) - Static method in interface alluxio.cli.ValidationTool
Converts the results of the ValidationTool.runAllTests() method into a map for digestion by other components.
convertToAlluxioPath(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
Converts the UFS path back to Alluxio path.
convertToByteString(Map<String, byte[]>) - Static method in class alluxio.util.CommonUtils
 
convertToFolderName(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Appends the directory suffix to the key.
convertToNames(UfsStatus[]) - Static method in class alluxio.underfs.UfsStatus
Converts an array of UFS file status to a listing result where each element in the array is a file or directory name.
convertToSingleValueMap(HttpHeaders) - Static method in class alluxio.s3.NettyRestUtils
Convert HttpHeaders to a single value map.
convertToUfsPath(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
Converts the Alluxio based path to UfsBaseFileSystem based path if needed.
convertUfsPathToAlluxioPath(AlluxioURI, AlluxioURI) - Static method in class alluxio.util.io.PathUtils
Converts the UFS path back to Alluxio path.
coordinators() - Method in class alluxio.master.job.plan.PlanTracker
A collection of all PlanCoordinator currently tracked by the job master.
copy(CopyRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
copy files from src to dst.
copy(CopyRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
copy() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed normally with the same value as this CompletableFuture when it completes normally.
copy() - Method in class alluxio.conf.AlluxioProperties
Makes a copy of the backing properties and returns them in a new object.
copy(CopyRequest, StreamObserver<CopyResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
copy(CopyRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
copy(CopyRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
copy(CopyRequest, StreamObserver<CopyResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
copy() - Method in class alluxio.underfs.UfsDirectoryStatus
 
copy() - Method in class alluxio.underfs.UfsFileStatus
 
copy() - Method in class alluxio.underfs.UfsStatus
Create a copy of UfsStatus.
copy(List<Route>, UfsReadOptions, WriteOptions) - Method in interface alluxio.worker.dora.DoraWorker
Copies files from src to dst.
copy(List<Route>, UfsReadOptions, WriteOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
copy(CopyRequest, StreamObserver<CopyResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
copy(Route, WriteOptions, FileSystem, FileSystem) - Static method in class alluxio.worker.task.CopyHandler
Copies a file from source to destination.
COPY_FAIL_FILE_COUNT - Static variable in class alluxio.master.job.CopyJob
 
COPY_FILE_COUNT - Static variable in class alluxio.master.job.CopyJob
 
COPY_JOB_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
COPY_RATE - Static variable in class alluxio.master.job.CopyJob
 
COPY_SIZE - Static variable in class alluxio.master.job.CopyJob
 
COPY_SKIP_FILE_COUNT - Static variable in class alluxio.master.job.CopyJob
 
copyAndMaskProperties(MountPOptions.Builder, Map<String, String>) - Method in class alluxio.RpcSensitiveConfigMask
 
copyGlobal() - Static method in class alluxio.conf.Configuration
 
CopyHandler - Class in alluxio.worker.task
CopyHandler is responsible for copying files.
CopyHandler() - Constructor for class alluxio.worker.task.CopyHandler
 
CopyJob - Class in alluxio.master.job
Copy job that copy a file or a directory from source to destination.
CopyJob(String, String, boolean, Optional<String>, String, OptionalLong, boolean, boolean, boolean, Iterable<FileInfo>, Optional<Job.FileFilter>) - Constructor for class alluxio.master.job.CopyJob
Constructor.
CopyJob.CopyTask - Class in alluxio.master.job
Loads blocks in a UFS through an Alluxio worker.
CopyJobFactory - Class in alluxio.master.job
Factory for creating CopyJobs that get file infos from master.
CopyJobFactory(CopyJobRequest, DefaultFileSystemMaster) - Constructor for class alluxio.master.job.CopyJobFactory
Create factory.
CopyJobPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CopyJobPOptions
CopyJobPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CopyJobPOptions
CopyJobPOptionsOrBuilder - Interface in alluxio.grpc
 
CopyJobRequest - Class in alluxio.job
The request of copying files.
CopyJobRequest(String, String, CopyJobPOptions) - Constructor for class alluxio.job.CopyJobRequest
 
copyObject(String, String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Copies an object to another key.
copyObject(String, String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
copyObject(String, String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
CopyObjectResult - Class in alluxio.s3
Result of an S3 Copy.
CopyObjectResult(String, long) - Constructor for class alluxio.s3.CopyObjectResult
Create a new CopyObjectResult.
CopyPartResult - Class in alluxio.proxy.s3
Result of an S3 UploadPartCopy.
CopyPartResult(String) - Constructor for class alluxio.proxy.s3.CopyPartResult
Create a new CopyPartResult.
copyProperties() - Method in interface alluxio.conf.AlluxioConfiguration
Gets a copy of the AlluxioProperties which back the AlluxioConfiguration.
copyProperties() - Static method in class alluxio.conf.Configuration
Create and return a copy of all properties.
copyProperties() - Method in class alluxio.conf.InstancedConfiguration
 
copyProperties() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
CopyRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CopyRequest
CopyRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CopyRequest
CopyRequestOrBuilder - Interface in alluxio.grpc
 
CopyResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CopyResponse
CopyResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.CopyResponse
CopyResponseOrBuilder - Interface in alluxio.grpc
 
CopyTask(List<Route>) - Constructor for class alluxio.master.job.CopyJob.CopyTask
Creates a new instance of CopyJob.CopyTask.
CoreMaster - Class in alluxio.master
Abstract class for masters that run in the core master process.
CoreMaster(CoreMasterContext, Clock, ExecutorServiceFactory) - Constructor for class alluxio.master.CoreMaster
 
CoreMasterContext - Class in alluxio.master
This class stores fields that are specific to core masters.
CoreMasterContext.Builder - Class in alluxio.master
Constructs CoreMasterContexts.
CORSFilter - Class in alluxio.web
A filter for adding the Cors header to the http header.
CORSFilter() - Constructor for class alluxio.web.CORSFilter
 
COS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
COS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_APP_ID - Static variable in class alluxio.conf.PropertyKey
 
COS_APP_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_CONNECTION_MAX - Static variable in class alluxio.conf.PropertyKey
 
COS_CONNECTION_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
COS_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_REGION - Static variable in class alluxio.conf.PropertyKey
 
COS_REGION - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
COS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
COS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
COSInputStream - Class in alluxio.underfs.cos
A stream for reading a file from COS.
COSMultipartUploadOutputStream - Class in alluxio.underfs.cos
Object storage multipart upload for COS.
COSMultipartUploadOutputStream(String, String, COS, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.cos.COSMultipartUploadOutputStream
Constructs a new stream for writing a file.
CosnUfsConstants - Class in alluxio
Ufs constants from compilation time by maven.
CosnUnderFileSystem - Class in alluxio.underfs.cosn
COSN UnderFileSystem implementation.
CosnUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.cosn.CosnUnderFileSystem
Constructs a new COSN UnderFileSystem.
CosNUnderFileSystemFactory - Class in alluxio.underfs.cosn
Factory for creating CosnUnderFileSystem.
CosNUnderFileSystemFactory() - Constructor for class alluxio.underfs.cosn.CosNUnderFileSystemFactory
 
COSOutputStream - Class in alluxio.underfs.cos
A stream for writing a file into COS.
COSOutputStream(String, String, COSClient, List<String>) - Constructor for class alluxio.underfs.cos.COSOutputStream
Creates a name instance of COSOutputStream.
COSPositionReader - Class in alluxio.underfs.cos
Implementation of ObjectPositionReader that reads from COS object store.
COSPositionReader(COSClient, String, String, long) - Constructor for class alluxio.underfs.cos.COSPositionReader
 
COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
 
COSUnderFileSystem - Class in alluxio.underfs.cos
Tencent Cloud COS UnderFileSystem implementation.
COSUnderFileSystem(AlluxioURI, COSClient, String, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.cos.COSUnderFileSystem
Constructor for COSUnderFileSystem.
COSUnderFileSystemFactory - Class in alluxio.underfs.cos
Factory for creating COSUnderFileSystem.
COSUnderFileSystemFactory() - Constructor for class alluxio.underfs.cos.COSUnderFileSystemFactory
Constructs a new COSUnderFileSystemFactory.
COUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.StatusSummary
 
CountedCompleter<T> - Class in alluxio.concurrent.jsr
A ForkJoinTask with a completion action performed when triggered and there are no remaining pending actions.
CountedCompleter(CountedCompleter<?>, int) - Constructor for class alluxio.concurrent.jsr.CountedCompleter
Creates a new CountedCompleter with the given completer and initial pending count.
CountedCompleter(CountedCompleter<?>) - Constructor for class alluxio.concurrent.jsr.CountedCompleter
Creates a new CountedCompleter with the given completer and an initial pending count of zero.
CountedCompleter() - Constructor for class alluxio.concurrent.jsr.CountedCompleter
Creates a new CountedCompleter with no completer and an initial pending count of zero.
counter(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add counter with the given name.
COUNTER_VALUE - Static variable in enum alluxio.grpc.MetricType
COUNTER represents values which can be incremented or decremented over time by certain operations.
counterWithTags(String, boolean, String...) - Static method in class alluxio.metrics.MetricsSystem
Get or add counter with the given name with tags.
CountingLatch - Class in alluxio.concurrent
Similar to CountDownLatch except that the count can either be increased or decreased.
CountingLatch() - Constructor for class alluxio.concurrent.CountingLatch
 
CountingRetry - Class in alluxio.retry
An option which allows retrying based on maximum count.
CountingRetry(int) - Constructor for class alluxio.retry.CountingRetry
Constructs a retry facility which allows max number of retries.
CpCommand - Class in alluxio.cli.fs.command
Copies a file or a directory in the Alluxio filesystem.
CpCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.CpCommand
 
crashed() - Method in class alluxio.thread.AutopsyThread
Checks if the thread has crashed.
create(Map<Object, Object>) - Method in class alluxio.cli.HdfsValidationToolFactory
 
create(Map<Object, Object>) - Static method in class alluxio.cli.HmsValidationTool
Creates an instance of HmsValidationTool.
create(Map<Object, Object>) - Method in class alluxio.cli.HmsValidationToolFactory
 
create(Map<Object, Object>) - Method in interface alluxio.cli.ValidationToolFactory
Creates a new instance of ValidationTool.
create(String, Map<Object, Object>) - Method in class alluxio.cli.ValidationToolRegistry
Creates a new instance of ValidationTool.
create(MasterClientContext) - Static method in class alluxio.client.block.BlockMasterClient.Factory
Factory method for BlockMasterClient.
create(FileSystemContext) - Static method in class alluxio.client.block.BlockStoreClient
Creates an Alluxio block store with default local hostname.
create(UserState, GrpcServerAddress, AlluxioConfiguration) - Static method in class alluxio.client.block.stream.BlockWorkerClient.Factory
Creates a new block worker client.
create(long, long) - Method in class alluxio.client.block.stream.BlockWorkerDataReader.Factory
 
create(FileSystemContext, long, long, OutStreamOptions) - Static method in class alluxio.client.block.stream.BlockWorkerDataWriter
Creates an instance of BlockWorkerDataWriter.
create(FileSystemContext, WorkerNetAddress, ReadRequest) - Static method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
Creates an instance of BufferCachingGrpcDataReader for block reads.
create(long, long) - Method in interface alluxio.client.block.stream.DataReader.Factory
Creates an instance of DataReader.
create(FileSystemContext, long, long, WorkerNetAddress, OutStreamOptions) - Static method in class alluxio.client.block.stream.DataWriter.Factory
 
create(long, long) - Method in class alluxio.client.block.stream.GrpcDataReader.Factory
 
create(FileSystemContext, WorkerNetAddress, long, long, RequestType, OutStreamOptions) - Static method in class alluxio.client.block.stream.GrpcDataWriter
 
create(long, long) - Method in class alluxio.client.block.stream.NettyDataReader.Factory
 
create(FileSystemContext, WorkerNetAddress, long, long, RequestType, OutStreamOptions) - Static method in class alluxio.client.block.stream.NettyDataWriter
 
create(long, long) - Method in class alluxio.client.block.stream.SharedGrpcDataReader.Factory
 
create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManager.Factory
 
create(AlluxioConfiguration, CacheManagerOptions, PageMetaStore) - Static method in class alluxio.client.file.cache.CacheManager.Factory
 
create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManagerOptions
 
create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long, double, double, HashFunction) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
Create a concurrent cuckoo filter with specified parameters.
create(Funnel<? super T>, long, int, int, int, int, SlidingWindowType, long, double, double, HashFunction) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
Create a concurrent cuckoo filter with size encoder.
create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long, double, double) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
Create a concurrent cuckoo filter with specified parameters.
create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long, double) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
Create a concurrent cuckoo filter with specified parameters.
create(Funnel<? super T>, long, int, int, int, SlidingWindowType, long) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
Create a concurrent cuckoo filter with specified parameters.
create(Funnel<? super T>, long, int, int, int) - Static method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
Create a concurrent cuckoo filter with specified parameters.
create(CacheEvictorOptions) - Static method in interface alluxio.client.file.cache.evictor.CacheEvictor
 
create(AlluxioConfiguration) - Static method in interface alluxio.client.file.cache.filter.CacheFilter
Create a CacheFilter.
create(CacheManagerOptions, PageMetaStore) - Static method in class alluxio.client.file.cache.LocalCacheManager
 
create(AlluxioConfiguration, CacheManager, CloseableSupplier<PositionReader>, URIStatus, long, CacheContext) - Static method in class alluxio.client.file.cache.LocalCachePositionReader
 
create(CacheManager, CloseableSupplier<PositionReader>, FileId, long, long, CacheContext) - Static method in class alluxio.client.file.cache.LocalCachePositionReader
 
create(CacheManagerOptions) - Static method in interface alluxio.client.file.cache.PageMetaStore
 
create(PageStoreOptions) - Static method in interface alluxio.client.file.cache.PageStore
Create an instance of PageStore.
create(AlluxioConfiguration) - Static method in interface alluxio.client.file.cache.ShadowCacheManager
 
create(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.store.PageStoreOptions
 
create(FileSystemContext, WorkerNetAddress, long, RequestType, OutStreamOptions) - Static method in class alluxio.client.file.dora.netty.NettyDataWriter
 
create(AlluxioConfiguration) - Static method in class alluxio.client.file.dora.WorkerLocationPolicy.Factory
Factory for creating WorkerLocationPolicy.
create() - Static method in class alluxio.client.file.FileSystem.Factory
 
create(AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystem.Factory
 
create(ClientContext) - Static method in class alluxio.client.file.FileSystem.Factory
 
create(FileSystemContext) - Static method in class alluxio.client.file.FileSystem.Factory
 
create(FileSystemContext, FileSystemOptions) - Static method in class alluxio.client.file.FileSystem.Factory
 
create(AlluxioConfiguration, List<InetSocketAddress>) - Static method in class alluxio.client.file.FileSystemContext
Creates a FileSystemContext with an empty subject , a null local block worker, and the given master addresses.
create() - Static method in class alluxio.client.file.FileSystemContext
Creates a FileSystemContext with an empty subject, default config and a null local block worker.
create(AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
Creates a FileSystemContext with an empty subject and a null local block worker.
create(Subject, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
 
create(ClientContext) - Static method in class alluxio.client.file.FileSystemContext
 
create(ClientContext, BlockWorker) - Static method in class alluxio.client.file.FileSystemContext
 
create(ClientContext, BlockWorker, List<InetSocketAddress>) - Static method in class alluxio.client.file.FileSystemContext
 
create(Subject, MasterInquireClient, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemContext
create(AlluxioConfiguration, List<InetSocketAddress>) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
Creates a FileSystemContext with an empty subject , a null local block worker, and the given master addresses.
create() - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
Creates a FileSystemContext with an empty subject, default config and a null local block worker.
create(AlluxioConfiguration) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
Creates a FileSystemContext with an empty subject and a null local block worker.
create(Subject, AlluxioConfiguration) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
 
create(ClientContext) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
 
create(ClientContext, BlockWorker) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
 
create(ClientContext, BlockWorker, List<InetSocketAddress>) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
 
create(Subject, MasterInquireClient, AlluxioConfiguration) - Method in class alluxio.client.file.FileSystemContext.FileSystemContextFactory
create(MasterClientContext) - Static method in class alluxio.client.file.FileSystemMasterClient.Factory
Factory method for FileSystemMasterClient.
create(AlluxioConfiguration, UserState) - Static method in class alluxio.client.job.JobContext
Creates a job context.
create(JobMasterClientContext) - Static method in class alluxio.client.job.JobMasterClient.Factory
Factory method for JobMasterClient.
create(String) - Static method in class alluxio.client.quota.CacheScope
 
create(MasterClientContext) - Static method in class alluxio.client.table.TableMasterClient.Factory
Factory method for TableMasterClient.
create(Subject, AlluxioConfiguration) - Static method in class alluxio.ClientContext
A client context with information about the subject and configuration of the client.
create(AlluxioConfiguration) - Static method in class alluxio.ClientContext
 
create() - Static method in class alluxio.ClientContext
 
create(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
create(String, CreateOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
create(String, S) - Method in interface alluxio.extensions.ExtensionFactory
Creates a new extension for the given path.
create(String, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
create(FileSystem, AlluxioConfiguration, FuseFileSystem) - Static method in class alluxio.fuse.auth.AuthPolicyFactory
Creates a new instance of AuthPolicy.
create(FileSystem, AlluxioConfiguration, Optional<FuseFileSystem>) - Static method in class alluxio.fuse.auth.CustomAuthPolicy
Creates a new custom auth policy.
create(FileSystem, AlluxioConfiguration, Optional<FuseFileSystem>) - Static method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
Creates a new launch user auth policy.
create(FileSystem, AlluxioConfiguration, Optional<FuseFileSystem>) - Static method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
Creates a new system auth policy.
create(AuthPolicy, long, long) - Static method in class alluxio.fuse.file.CreateFileStatus
Creates a CreateFileStatus.
create(FileSystem, AuthPolicy, FuseReadWriteLockManager, AlluxioURI, int, long) - Static method in class alluxio.fuse.file.FuseFileInOrOutStream
create(FileSystem, FuseReadWriteLockManager, AlluxioURI) - Static method in class alluxio.fuse.file.FuseFileInStream
Creates a FuseFileInStream.
create(FileSystem, AuthPolicy, FuseReadWriteLockManager, AlluxioURI, int, long) - Static method in class alluxio.fuse.file.FuseFileOutStream
create(FileSystem, FuseReadWriteLockManager, AlluxioURI) - Static method in class alluxio.fuse.file.FusePositionReader
 
create(FileSystem, AuthPolicy, FuseReadWriteLockManager, AlluxioURI, int, long) - Static method in class alluxio.fuse.file.FusePositionReadOrOutStream
create(AlluxioURI, int, long) - Method in interface alluxio.fuse.file.FuseStreamFactory
Factory method for creating/opening a file and creating an implementation of FuseFileStream.
create(AlluxioURI, int, long) - Method in class alluxio.fuse.file.SimpleFuseStreamFactory
Factory method for creating/opening a file and creating an implementation of FuseFileStream.
create(FuseOptions) - Static method in class alluxio.fuse.meta.UpdateChecker
Creates a UpdateChecker.
create(String, long, FuseFileInfo) - Method in class alluxio.fuse.StackFS
 
create(InetSocketAddress) - Static method in class alluxio.grpc.GrpcServerAddress
 
create(String, SocketAddress) - Static method in class alluxio.grpc.GrpcServerAddress
 
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class alluxio.hadoop.AbstractFileSystem
Attempts to create a file.
create(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
create(String, long, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
create(String) - Static method in class alluxio.job.plan.batch.BatchedJobDefinition.JobDefinitionFactory
 
create(CompositeConfig) - Method in class alluxio.job.workflow.composite.CompositeExecutionFactory
 
create(T) - Method in interface alluxio.job.workflow.WorkflowExecutionFactory
Creates a new WorkflowExecution based on the workflow configuration.
create() - Static method in class alluxio.master.AlluxioMasterProcess.Factory
Creates a new AlluxioMasterProcess.
create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.block.BlockMasterFactory
 
create(BlockMaster, long, StreamObserver<RegisterWorkerPRequest>) - Static method in class alluxio.master.block.WorkerRegisterContext
Creates a new WorkerRegisterContext.
create(FileSystemMasterView) - Static method in class alluxio.master.file.async.AsyncPersistHandler.Factory
Creates a new instance of AsyncPersistHandler.
create(CheckAccessPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckAccessContext
 
create(CheckConsistencyPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckConsistencyContext
 
create(CompleteFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CompleteFileContext
 
create(CreateDirectoryPOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateDirectoryContext
 
create(CreateFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateFileContext
 
create(DeletePOptions.Builder) - Static method in class alluxio.master.file.contexts.DeleteContext
 
create(ExistsPOptions.Builder) - Static method in class alluxio.master.file.contexts.ExistsContext
 
create(FreePOptions.Builder) - Static method in class alluxio.master.file.contexts.FreeContext
 
create(GetStatusPOptions.Builder) - Static method in class alluxio.master.file.contexts.GetStatusContext
 
create(ListStatusPOptions.Builder) - Static method in class alluxio.master.file.contexts.ListStatusContext
 
create(ListStatusPartialPOptions.Builder) - Static method in class alluxio.master.file.contexts.ListStatusContext
 
create(LoadMetadataPOptions.Builder) - Static method in class alluxio.master.file.contexts.LoadMetadataContext
 
create(MountPOptions.Builder) - Static method in class alluxio.master.file.contexts.MountContext
 
create(RenamePOptions.Builder) - Static method in class alluxio.master.file.contexts.RenameContext
 
create(ScheduleAsyncPersistencePOptions.Builder) - Static method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
 
create(SetAclPOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAclContext
 
create(SetAttributePOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAttributeContext
 
create(FileSystemHeartbeatPOptions.Builder) - Static method in class alluxio.master.file.contexts.WorkerHeartbeatContext
Merges and embeds the given FileSystemHeartbeatPOptions with the corresponding master options.
create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.file.FileSystemMasterFactory
 
create(InodeStore, InodeDirectory) - Static method in class alluxio.master.file.meta.InodeTreeBufferedIterator
Creates buffered iterator with closeable interface.
create(long, long, String, CreateDirectoryContext) - Static method in class alluxio.master.file.meta.MutableInodeDirectory
create(long, long, String, long, CreateFileContext) - Static method in class alluxio.master.file.meta.MutableInodeFile
Creates an MutableInodeFile.
create(MountTable, Clock) - Static method in class alluxio.master.file.meta.UfsAbsentPathCache.Factory
 
create(MountTable) - Static method in class alluxio.master.file.meta.UfsBlockLocationCache.Factory
 
create() - Method in class alluxio.master.job.CopyJobFactory
 
create(JobRequest, DefaultFileSystemMaster) - Static method in class alluxio.master.job.JobFactoryProducer
 
create(Journal.JournalEntry, DefaultFileSystemMaster) - Static method in class alluxio.master.job.JobFactoryProducer
 
create() - Method in class alluxio.master.job.JournalCopyJobFactory
 
create() - Method in class alluxio.master.job.JournalLoadJobFactory
 
create() - Method in class alluxio.master.job.JournalMoveJobFactory
 
create() - Method in class alluxio.master.job.LoadJobFactory
 
create() - Method in class alluxio.master.job.MoveJobFactory
 
create(CommandManager, JobServerContext, List<WorkerInfo>, Long, JobConfig, Consumer<PlanInfo>) - Static method in class alluxio.master.job.plan.PlanCoordinator
Creates a new instance of the PlanCoordinator.
create(URI) - Static method in class alluxio.master.journal.JournalFileParser.Factory
Creates a journal parser given the location.
create(MasterRegistry, MasterContext) - Method in class alluxio.master.journal.JournalMasterFactory
 
create(String) - Method in class alluxio.master.journalv0.Journal.Factory
 
create(URI) - Static method in class alluxio.master.journalv0.Journal.Factory
Creates a new read-only journal using the given location.
create(String) - Method in interface alluxio.master.journalv0.JournalFactory
Creates a new journal using the given name.
create() - Static method in class alluxio.master.journalv0.JournalFormatter.Factory
Factory method for JournalFormatter.
create(String) - Method in class alluxio.master.journalv0.MutableJournal.Factory
 
create(URI) - Static method in class alluxio.master.journalv0.MutableJournal.Factory
Creates a new read-write journal using the given location.
create() - Static method in class alluxio.master.LocalAlluxioMaster
Creates a new local Alluxio master with an isolated work directory and port.
create(String) - Static method in class alluxio.master.LocalAlluxioMaster
Creates a new local Alluxio master with a isolated port.
create(MasterRegistry, T) - Method in interface alluxio.master.MasterFactory
Factory method to create a new master instance.
create(AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
 
create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.meta.MetaMasterFactory
 
create(MasterRegistry, CoreMasterContext) - Method in class alluxio.master.metrics.MetricsMasterFactory
 
create(Job.FileFilter) - Method in class alluxio.master.predicate.DatePredicate.Factory
 
create(Job.FileFilter) - Static method in interface alluxio.master.predicate.FilePredicate
Creates a file predicate from a file filter.
create(Job.FileFilter) - Method in interface alluxio.master.predicate.FilePredicateFactory
Creates a predicate from a file filter.
create(Job.FileFilter) - Method in class alluxio.master.predicate.TimePredicate.DateFromFileNameOlderThanFactory
 
create(Job.FileFilter) - Method in class alluxio.master.predicate.TimePredicate.Factory
 
create() - Static method in class alluxio.master.service.jvmmonitor.JvmMonitorService.Factory
 
create() - Static method in class alluxio.master.service.metrics.MetricsService.Factory
 
create(InetSocketAddress, MasterProcess, MasterRegistry) - Static method in class alluxio.master.service.rpc.RpcServerService.Factory
Creates a simple service wrapper around a grpc server to manager the grpc server for the master process.
create(InetSocketAddress, MasterProcess) - Static method in class alluxio.master.service.web.WebServerService.Factory
 
create(AlluxioConfiguration) - Static method in class alluxio.membership.EtcdMembershipManager
 
create() - Static method in class alluxio.membership.MasterMembershipManager
 
create(AlluxioConfiguration) - Static method in class alluxio.membership.MembershipManager.Factory
 
create(AlluxioConfiguration) - Static method in class alluxio.membership.StaticMembershipManager
 
create() - Static method in class alluxio.proxy.ProxyProcess.Factory
 
create(FileInStream, long, S3RangeSpec) - Static method in class alluxio.proxy.s3.RangeFileInStream.Factory
 
create(S3Handler) - Static method in class alluxio.proxy.s3.S3BucketTask.Factory
Marshall the request and create corresponding bucket level S3 task.
create(S3Handler) - Static method in class alluxio.proxy.s3.S3ObjectTask.Factory
Marshall the request and create corresponding object level S3 task.
create(Iterator<? extends T>, Consumer<Void>) - Static method in class alluxio.resource.CloseableIterator
Wrap around an iterator with a resource to close.
create(AlluxioConfiguration) - Static method in class alluxio.s3.auth.Authenticator.Factory
Creates and initializes Authenticator implementation.
create(String) - Static method in class alluxio.s3.S3RangeSpec.Factory
Create S3RangeSpec from http range header.
create(String) - Static method in class alluxio.s3.signature.AwsCredential
Parse credential value.
create() - Method in interface alluxio.scheduler.job.JobFactory
 
create(AuthType, AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticationProvider.Factory
 
create(Subject, AlluxioConfiguration, boolean) - Method in class alluxio.security.user.NoopUserState.Factory
 
create(Subject, AlluxioConfiguration, boolean) - Method in class alluxio.security.user.SimpleUserState.Factory
 
create(AlluxioConfiguration) - Static method in class alluxio.security.user.UserState.Factory
 
create(AlluxioConfiguration, Subject) - Static method in class alluxio.security.user.UserState.Factory
 
create(AlluxioConfiguration, Subject, CommonUtils.ProcessType) - Static method in class alluxio.security.user.UserState.Factory
 
create(Subject, AlluxioConfiguration, boolean) - Method in interface alluxio.security.user.UserStateFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.adl.AdlUnderFileSystemFactory
 
create(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
create(String, CreateOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cos.COSUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
 
create(String, UfsStatus) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UfsStatus, String) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UfsStatus, String, AccessControlList) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.gcs.GCSUnderFileSystemFactory
 
create(String, CreateOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
 
create(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.local.LocalUnderFileSystemFactory
 
create(String, CreateOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.obs.OBSUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.oss.OSSUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.s3a.S3AUnderFileSystemFactory
 
create(String) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the indicated name.
create(String, CreateOptions) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the specified CreateOptions.
create(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates the UnderFileSystem instance according to its UFS path.
create(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates a client for operations involved with the under file system.
create(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
Creates a new client for accessing the given path.
create(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
create(String, CreateOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
create(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.wasb.WasbUnderFileSystemFactory
 
create(String) - Static method in class alluxio.uri.URI.Factory
Creates a URI from a string.
create(String, Authority, String, String) - Static method in class alluxio.uri.URI.Factory
Creates a URI from components.
create(URI, URI) - Static method in class alluxio.uri.URI.Factory
Resolves a child URI against a parent URI.
create(URI, String, boolean) - Static method in class alluxio.uri.URI.Factory
 
create() - Static method in class alluxio.util.compression.DirectoryMarshaller.Factory
 
create() - Method in interface alluxio.util.executor.ExecutorServiceFactory
 
create(AlluxioConfiguration) - Static method in class alluxio.util.network.tls.SslContextProvider.Factory
Creates and initializes SslContextProvider implementation based on Alluxio configuration.
create(AlluxioConfiguration, CacheManager, UnderFileSystem, String, String, long, long) - Static method in class alluxio.worker.dora.PagedFileReader
Creates a new PagedFileReader.
create(JobMasterClientContext) - Static method in class alluxio.worker.job.JobMasterClient.Factory
Factory method for JobMasterClient.
create() - Static method in class alluxio.worker.JobWorkerProcess.Factory
 
create(T) - Method in interface alluxio.worker.netty.AbstractReadHandler.PacketReader.Factory
Creates a new packet reader.
create(BlockReadRequest) - Method in class alluxio.worker.netty.FileReadHandler.FilePacketReaderFactory
 
create(S3NettyHandler) - Static method in class alluxio.worker.s3.S3NettyBucketTask.Factory
Marshall the request and create corresponding bucket level S3 task.
create(S3NettyHandler) - Static method in class alluxio.worker.s3.S3NettyObjectTask.Factory
Marshall the request and create corresponding object level S3 task.
create() - Static method in class alluxio.worker.WorkerProcess.Factory
 
CREATE_CHECK_FILE - Static variable in class alluxio.cli.fs.command.ConsistentHashCommand
 
CREATE_DIRECTORY - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
CREATE_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
CREATE_UFS_FILE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
CREATE_UFS_FILE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
createAmazonS3(AWSCredentialsProvider, ClientConfiguration, AwsClientBuilder.EndpointConfiguration, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
Create an AmazonS3 client.
createAmazonS3Async(UnderFileSystemConfiguration, ClientConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
Create an async S3 client.
CREATEANCESTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
 
createAndAbortMultipartFileTest() - Method in class alluxio.cli.S3ASpecificOperations
Test for creating and aborting a multipart file.
createAnInstance(FileSystem, FileSystemContext) - Method in class alluxio.client.file.DoraCacheFileSystem.DoraCacheFileSystemFactory
 
createAtomicTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating file atomic.
createAuditContext(String, AlluxioURI, AlluxioURI, Inode) - Method in class alluxio.master.file.DefaultFileSystemMaster
Creates a FileSystemMasterAuditContext instance.
createAuditContext(String, String, String, String) - Method in class alluxio.proxy.s3.S3Handler
Creates a S3AuditContext instance.
createAuditContext(String, String, String, String) - Method in class alluxio.worker.s3.S3NettyHandler
Creates a S3AuditContext instance.
createAwsCredentialsProvider(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createBaseFileSystem(FileSystemContext, FuseOptions) - Method in class alluxio.fuse.AlluxioFuse
 
createBaseMasterContext() - Method in class alluxio.master.AlluxioMasterProcess
 
createBaseRpcServer() - Method in class alluxio.master.AlluxioJobMasterProcess
 
createBaseRpcServer() - Method in class alluxio.master.AlluxioMasterProcess
 
createBaseRpcServer() - Method in class alluxio.master.MasterProcess
 
createBlock(long, long, int, CreateBlockOptions) - Method in interface alluxio.worker.block.BlockStore
Creates a block in Alluxio managed space.
createBlock(long, long, int, CreateBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Creates a block in Alluxio managed space.
createBlockDeletionContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createBlockId(long, long) - Static method in class alluxio.master.block.BlockId
 
CreateBlockOptions - Class in alluxio.worker.block
Method options for create a block.
CreateBlockOptions(String, String, long) - Constructor for class alluxio.worker.block.CreateBlockOptions
Constructor.
createBlockPath(String, String) - Static method in class alluxio.util.io.FileUtils
Creates the local block path and all the parent directories.
createBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockStore
Creates the block reader to read from Alluxio block or UFS block.
createBlockReader(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a reader of an existing block to read data from this block.
createBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Creates the block reader to read from Alluxio block or UFS block.
createBlockRemote(long, long, String, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a block.
createBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a BlockWriter for an existing temporary block which is already created by BlockStore.createBlock(long, long, int, alluxio.worker.block.CreateBlockOptions).
createBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a BlockWriter for an existing temporary block which is already created by BlockWorker.createBlock(long, long, int, alluxio.worker.block.CreateBlockOptions).
createBucket(String, String, String, String, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Creates a bucket, or puts bucket tags on an existing bucket.
createCallback(String, long, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
createCancelResponse() - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response in CANCELLED state.
createCancelResponseEvent() - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
Create a CancelledResponseEvent.
createChannel() - Method in class alluxio.AbstractClient
 
createChannelErrorResponseEvent(Throwable) - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
Create a ChannelErrorResponseEvent.
createCheckFile() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
Create the check file.
createClientBootstrap(SocketAddress) - Static method in class alluxio.network.netty.NettyClient
Creates and returns a new Netty client bootstrap for clients to connect to remote servers.
createCloseableIterator(RocksIterator, RocksUtils.RocksIteratorParser<T>, Supplier<Void>, RocksSharedLockHandle) - Static method in class alluxio.master.metastore.rocks.RocksUtils
Used to wrap an CloseableIterator over RocksIterator.
createConfiguration(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.adl.AdlUnderFileSystem
Prepares the configuration for this Adl as an HDFS configuration.
createConfiguration(UnderFileSystemConfiguration) - Static method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
Prepares the Hadoop configuration necessary to successfully obtain a FileSystem instance that can access the provided path.
createConfiguration(UnderFileSystemConfiguration, Boolean) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
Prepares the configuration for this Wasb as an HDFS configuration.
CREATED_AT_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyInfo
 
CREATED_AT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
CREATED_VALUE - Static variable in enum alluxio.grpc.Status
CREATED = 1;
CREATED_VALUE - Static variable in enum alluxio.proto.journal.Job.PJobState
CREATED = 1;
createDataResponseEvent(DataBuffer) - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
Create a DataResponseEvent.
createDatePredicate(String) - Method in class alluxio.master.predicate.DatePredicate.Factory
Creates a FilePredicate from the string value.
createDeleteFileConjuctionTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating and deleting file conjunction.
createDir(String) - Static method in class alluxio.util.io.FileUtils
Creates an empty directory and its intermediate directories if necessary.
createDirect(String, CreateOptions) - Method in interface alluxio.underfs.AtomicFileOutputStreamCallback
Creates a file in the under file system with the specified CreateOptions.
createDirect(String, CreateOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
createDirect(String, CreateOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
createDirect(String, CreateOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
createDirectory(CreateDirectoryPRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Create a directory.
createDirectory(CreateDirectoryPRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
createDirectory(String, CreateDirectoryPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Create a dir.
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
createDirectory(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.createDirectory(AlluxioURI, CreateDirectoryPOptions) with default options.
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in interface alluxio.client.file.FileSystem
Creates a directory.
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Creates a new directory.
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
createDirectory(AlluxioURI, CreateDirectoryPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Creates a directory.
createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Creates a directory.
createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Creates a directory.
createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Creates a directory.
createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Creates a directory.
createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Creates a directory.
createDirectory(CreateDirectoryPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Creates a directory.
createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Creates a directory.
CreateDirectory - Class in alluxio.master.backcompat.ops
Test for directory creation.
CreateDirectory() - Constructor for class alluxio.master.backcompat.ops.CreateDirectory
 
createDirectory(AlluxioURI, CreateDirectoryContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createDirectory(AlluxioURI, CreateDirectoryContext) - Method in interface alluxio.master.file.FileSystemMaster
Creates a directory for a given path.
createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
createDirectory(String, CreateDirectoryPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
createDirectory(String, CreateDirectoryPOptions) - Method in interface alluxio.worker.dora.DoraWorker
Create a directory.
createDirectory(String, CreateDirectoryPOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
createDirectory(CreateDirectoryPRequest, StreamObserver<CreateDirectoryPResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
CreateDirectoryContext - Class in alluxio.master.file.contexts
Used to merge and wrap CreateDirectoryPOptions.
createDirectoryDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
createDirectoryDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
 
CreateDirectoryPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateDirectoryPOptions
CreateDirectoryPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateDirectoryPOptions
CreateDirectoryPOptionsOrBuilder - Interface in alluxio.grpc
 
CreateDirectoryPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateDirectoryPRequest
CreateDirectoryPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateDirectoryPRequest
CreateDirectoryPRequestOrBuilder - Interface in alluxio.grpc
 
CreateDirectoryPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateDirectoryPResponse
CreateDirectoryPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateDirectoryPResponse
CreateDirectoryPResponseOrBuilder - Interface in alluxio.grpc
 
createDomainSocketDataServer(DataWorker) - Method in class alluxio.worker.DataServerFactory
 
createEmptyFileTest() - Method in class alluxio.cli.S3ASpecificOperations
Test for creating an empty file using streaming upload.
createEmptyObject(String) - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
createEmptyObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
createEmptyObject(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
createEmptyObject(String) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates a zero-byte object used to encode a directory.
createEmptyObject(String) - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
createEmptyObject(String) - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
createEmptyObject(String) - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createEmptyTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating empty file.
createEndpointConfiguration(UnderFileSystemConfiguration, ClientConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
Creates an endpoint configuration.
createEofResponseEvent() - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
Create an EofResponseEvent.
createErrorResponse(Throwable, String) - Static method in class alluxio.s3.S3ErrorResponse
Creates an error response using the given exception.
createEventLoop(ChannelType, int, String, boolean) - Static method in class alluxio.util.network.NettyUtils
Creates a Netty EventLoopGroup based on ChannelType.
createFile(CreateFilePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Create file request from client to worker.
createFile(CreateFilePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
createFile(String, CreateFilePOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Create File.
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
createFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.createFile(AlluxioURI, CreateFilePOptions) with default options.
createFile(AlluxioURI, CreateFilePOptions) - Method in interface alluxio.client.file.FileSystem
Creates a file.
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
createFile(AlluxioURI, CreateFilePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Creates a new file.
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
createFile(AlluxioURI, CreateFilePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
createFile(int, long) - Method in class alluxio.fsmaster.FileSystemMasterBase
 
createFile(FileSystem, AuthPolicy, AlluxioURI, CreateFileStatus) - Static method in class alluxio.fuse.AlluxioFuseUtils
Creates a file in alluxio namespace.
createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Creates a file.
createFile(CreateFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Creates a file.
createFile(CreateFilePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Creates a file.
createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Creates a file.
createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Creates a file.
createFile(CreateFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Creates a file.
createFile(CreateFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Creates a file.
createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Creates a file.
CreateFile - Class in alluxio.master.backcompat.ops
Test for file creation.
CreateFile() - Constructor for class alluxio.master.backcompat.ops.CreateFile
 
createFile(FileSystem, AlluxioURI) - Static method in class alluxio.master.backcompat.Utils
Creates a file at the given path.
createFile(FileSystem, AlluxioURI, CreateFilePOptions) - Static method in class alluxio.master.backcompat.Utils
Creates a file at the given path.
createFile(AlluxioURI, CreateFileContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createFile(AlluxioURI, CreateFileContext) - Method in interface alluxio.master.file.FileSystemMaster
Creates a file (not a directory) for a given path.
createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
createFile(String, CreateFilePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
createFile(String) - Static method in class alluxio.util.io.FileUtils
Creates an empty file and its intermediate directories if necessary.
createFile(String, CreateFilePOptions) - Method in interface alluxio.worker.dora.DoraWorker
Create File.
createFile(String, CreateFilePOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
createFile(CreateFilePRequest, StreamObserver<CreateFilePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
CreateFileContext - Class in alluxio.master.file.contexts
Implementation of OperationContext used to merge and wrap CreateFilePOptions.
createFileDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
createFileDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
 
CreateFileEntry<T extends OutputStream> - Class in alluxio.fuse
Convenience class to encapsulate output stream and its information (path, id) for create alluxio file.
CreateFileEntry(long, String, T) - Constructor for class alluxio.fuse.CreateFileEntry
Constructs a new CreateFileEntry for an Alluxio file.
createFileId(long) - Static method in class alluxio.util.IdUtils
Creates an id for a file based on the given id of the container.
createFileLessThanOnePartTest() - Method in class alluxio.cli.S3ASpecificOperations
Test for creating a file with data less than one part.
CreateFilePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateFilePOptions
CreateFilePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateFilePOptions
CreateFilePOptionsOrBuilder - Interface in alluxio.grpc
 
CreateFilePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateFilePRequest
CreateFilePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateFilePRequest
CreateFilePRequestOrBuilder - Interface in alluxio.grpc
 
CreateFilePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateFilePResponse
CreateFilePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.CreateFilePResponse
CreateFilePResponseOrBuilder - Interface in alluxio.grpc
 
createFileReader(String, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.dora.DoraWorker
Creates the file reader to read from Alluxio dora.
createFileReader(String, long, boolean, Protocol.OpenUfsBlockOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
CreateFileStatus - Class in alluxio.fuse.file
The file status of ongoing fuse out stream.
CreateFileStatus(long, long, long, long) - Constructor for class alluxio.fuse.file.CreateFileStatus
Constructs a new CreateFileStatus.
createFileSystemContextId() - Static method in class alluxio.util.IdUtils
 
createFileSystemForUser(String, FileSystem) - Static method in class alluxio.proxy.s3.S3RestUtils
 
createFileWriter(String, String) - Method in interface alluxio.worker.dora.DoraWorker
Creates the file writer to write to Alluxio dora.
createFileWriter(String, String) - Method in class alluxio.worker.dora.PagedDoraWorker
 
createForAddresses(List<InetSocketAddress>, AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
 
createForJobMaster(AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
 
createForPath(String, Optional<byte[]>) - Method in class alluxio.membership.AlluxioEtcdClient
Create a path with given value in non-transactional way.
createForRoot(AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
 
createForWorker(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManagerOptions
 
createForWorkerPageStore(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.store.PageStoreOptions
 
createFrameDecoder() - Static method in class alluxio.network.protocol.RPCMessage
Creates a decoder that splits up the incoming ByteBuf into new ByteBuf's according to a length field in the input.
createFullAccess() - Static method in class alluxio.security.authorization.Mode
Creates the "full access" mode.
createFuseFileSystem(FileSystemContext, FileSystem, FuseOptions) - Method in class alluxio.fuse.AlluxioFuse
Create a FuseFileSystem instance.
createGrpcDataReader(WorkerNetAddress, Protocol.OpenUfsBlockOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
 
createHandler(String, HttpServletRequest, HttpServletResponse) - Static method in class alluxio.proxy.s3.S3Handler
Create a S3Handler based on the incoming Request.
createHandler(ChannelHandlerContext, HttpRequest, FileSystem, DoraWorker, AsyncUserAccessAuditLogWriter) - Static method in class alluxio.worker.s3.S3NettyHandler
Create a S3Handler based on the incoming Request.
CreateHmsClientValidationTask - Class in alluxio.cli.hms
A validation task that generates a new Hive Metastore client and verifies the connection.
CreateHmsClientValidationTask(int, MetastoreValidationTask<?, String>) - Constructor for class alluxio.cli.hms.CreateHmsClientValidationTask
Create a new instance of CreateHmsClientValidationTask.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.abfs.AbfsUnderFileSystem
Creates a new AbfsUnderFileSystem instance.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.adl.AdlUnderFileSystem
Factory method to construct a new Adl UnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
Factory method to constructs a new CephFS UnderFileSystem instance.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystem
Factory method to constructs a new cephfs-hadoop UnderFileSystem instance.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cos.COSUnderFileSystem
Constructs a new instance of COSUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.cosn.CosnUnderFileSystem
Factory method to constructs a new Cosn UnderFileSystem instance.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.gcs.GCSUnderFileSystem
Constructs a new instance of GCSUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
Constructs a new instance of GCSV2UnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
Factory method to constructs a new HDFS UnderFileSystem instance.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.obs.OBSUnderFileSystem
Constructs a new instance of OBSUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.oss.OSSUnderFileSystem
Constructs a new instance of OSSUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.ozone.OzoneUnderFileSystem
Factory method to constructs a new Ozone UnderFileSystem instance.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.s3a.S3AUnderFileSystem
Constructs a new instance of S3AUnderFileSystem.
createInstance(AlluxioURI, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.wasb.WasbUnderFileSystem
Factory method to construct a new Wasb UnderFileSystem.
createInternalSessionId() - Static method in class alluxio.Sessions
 
createJniFuseSystem(FileSystemContext, FileSystem, FuseOptions) - Method in class alluxio.fuse.AlluxioFuse
 
createJournal(Master) - Method in interface alluxio.master.journal.JournalSystem
Creates a journal for the given state machine.
createJournal(Master) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
createJournal(Master) - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
createJournal(Master) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
createJournalContext() - Method in class alluxio.master.AbstractMaster
 
createJournalContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createJournalContext() - Method in interface alluxio.master.journal.Journal
 
createJournalContext() - Method in class alluxio.master.journal.noop.NoopJournal
 
createJournalContext() - Method in class alluxio.master.journal.raft.RaftJournal
 
createJournalContext() - Method in class alluxio.master.journal.ufs.UfsJournal
 
createJournalContext() - Method in interface alluxio.master.Master
 
createJournalContext() - Method in class alluxio.master.NoopMaster
 
createLease(long, long, TimeUnit) - Method in class alluxio.membership.AlluxioEtcdClient
Create a lease with timeout and ttl.
createLease() - Method in class alluxio.membership.AlluxioEtcdClient
Create lease with default ttl and timeout.
createLoginContext(AuthType, Subject, ClassLoader, Configuration, CallbackHandler) - Static method in class alluxio.util.SecurityUtils
Creates a new LoginContext with the correct class loader.
createMasters(MasterRegistry, MasterContext) - Static method in class alluxio.master.MasterUtils
Creates all the masters and registers them to the master registry.
createMetaMasterConfigClient(MasterClientContext) - Method in class alluxio.client.file.ConfigHashSync
 
createMountId() - Static method in class alluxio.util.IdUtils
 
createMountSpecificConf(Map<String, ? extends Object>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
Creates a new instance from the current configuration and adds in new properties.
createMultipartFileTest() - Method in class alluxio.cli.S3ASpecificOperations
Test for creating a multipart file.
createNettyDataReader(WorkerNetAddress, Protocol.OpenUfsBlockOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
 
createNettyErrorResponse(Throwable, String) - Static method in class alluxio.s3.S3ErrorResponse
Creates an error response using the given exception.
createNettyErrorResponse(S3Exception, String) - Static method in class alluxio.s3.S3ErrorResponse
Creates an error response using the given exception.
createNettyPositionReader(URIStatus, Protocol.OpenUfsBlockOptions, Optional<CloseableSupplier<PositionReader>>) - Method in class alluxio.client.file.dora.DoraCacheClient
 
createNewClassInstance(Class<T>, Class<?>[], Object[]) - Static method in class alluxio.util.CommonUtils
Creates new instance of a class by calling a constructor that receives ctorClassArgs arguments.
createNewPath(String, boolean) - Method in class alluxio.uri.MultiPartSchemeURI
 
createNewPath(String, boolean) - Method in class alluxio.uri.StandardURI
 
createNewPath(String, boolean) - Method in interface alluxio.uri.URI
 
createNewResource() - Method in class alluxio.client.block.BlockMasterClientPool
 
createNewResource() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
 
createNewResource() - Method in class alluxio.client.file.FileSystemMasterClientPool
 
createNewResource() - Method in class alluxio.client.job.JobMasterClientPool
 
createNewResource() - Method in class alluxio.network.netty.NettyChannelPool
Creates a netty channel instance.
createNewResource() - Method in class alluxio.resource.DynamicResourcePool
Creates a new resource.
createNewResource() - Method in class alluxio.resource.ResourcePool
Creates a new resource which will be added to the resource pool after the user is done using it.
createNewResource() - Method in class alluxio.underfs.ByteBufferResourcePool
 
createNewResource() - Method in class alluxio.worker.block.BlockMasterClientPool
 
createNoAccess() - Static method in class alluxio.security.authorization.Mode
Creates the "no access" mode.
createNonexistingFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
createNonexistingFile(String, CreateOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
createNonexistingFile(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
createNonexistingFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
createNonexistingFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the indicated name.
createNonexistingFile(String, CreateOptions) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the specified CreateOptions.
createNonexistingFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
createNonRecursive(Path, FsPermission, boolean, int, short, long, Progressable) - Method in class alluxio.hadoop.AbstractFileSystem
Deprecated.
API only for 0.20-append
createNoParentTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating file without parent.
createObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates an OutputStream for object uploads.
createObject(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
createObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
createObjectOrUploadPart(String, String, String, String, S3Constants.Directive, String, S3Constants.Directive, String, String, String, String, Integer, String, String, String, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Uploads an object or part of an object in multipart upload.
createOkResponse(DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates an OK response with data.
createOpenAtPositionTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating file and opening at position.
createOpenEmptyTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating and opening empty file.
createOpenExistingLargeFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating and open existing large file.
createOpenFilesLimitValidationTask() - Static method in class alluxio.cli.UserLimitValidationTask
Creates a validation task for checking whether the user limit for number of open files is within reasonable range.
createOpenLargeTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating and opening large file.
createOpenSkip() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for create file, open and seek.
createOpenTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating and opening file.
CreateOptions - Class in alluxio.underfs.options
Method options for creating a file in UnderFileSystem.
CreateOptions(String) - Constructor for class alluxio.underfs.options.CreateOptions
Constructs a default CreateOptions.
createOrGetAppIdFromConfig(AlluxioConfiguration) - Static method in class alluxio.util.IdUtils
 
createOrRefreshOssStsClient(UnderFileSystemConfiguration) - Method in class alluxio.underfs.oss.StsOssClientProvider
Create Or Refresh the STS OSS client.
createPacketWriter(BlockWriteRequestContext, Channel) - Method in class alluxio.worker.netty.FileWriteHandler
 
createPacketWriter(UfsFileWriteRequestContext, Channel) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
createPageStoreDir(CacheEvictorOptions, PageStoreOptions) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
Create an instance of PageStoreDir.
createPageStoreDirs(CacheManagerOptions) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
Create a list of PageStoreDir based on the configuration.
createParentTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating file with parent.
createPath(RpcContext, LockedInodePath, CreatePathContext<?, ?>) - Method in class alluxio.master.file.meta.InodeTree
Creates a file or directory at path.
CreatePathContext<T extends com.google.protobuf.GeneratedMessageV3.Builder<?>,K extends CreatePathContext<?,?>> - Class in alluxio.master.file.contexts
Wrapper for CreateFilePOptions or CreateDirectoryPOptions with additional context data.
CreatePathContext(T) - Constructor for class alluxio.master.file.contexts.CreatePathContext
Creates context with given option data.
createPathDepths(int) - Method in class alluxio.fsmaster.FileSystemMasterBase
 
createProgressThread(PrintStream) - Static method in class alluxio.util.CommonUtils
Convenience method for calling CommonUtils.createProgressThread(long, PrintStream) with an interval of 2 seconds.
createProgressThread(long, PrintStream) - Static method in class alluxio.util.CommonUtils
Creates a thread which will write "." to the given print stream at the given interval.
createRateLimiter(long) - Static method in class alluxio.proxy.s3.S3RestUtils
Create a rate limiter for given rate.
createRateLimiter(long) - Static method in interface alluxio.util.RateLimiter
 
createReader(CheckpointInputStream) - Method in interface alluxio.master.journal.checkpoint.CheckpointFormat
 
createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat
 
createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.InodeProtosCheckpointFormat
 
createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.JournalCheckpointFormat
 
createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.LongCheckpointFormat
 
createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.LongsCheckpointFormat
 
createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.TarballCheckpointFormat
 
createReader(CheckpointInputStream) - Method in class alluxio.master.journal.checkpoint.ZipCheckpointFormat
 
createReadRequest(Protocol.ReadRequest) - Method in class alluxio.worker.netty.AbstractReadHandler
 
createReadRequest(Protocol.ReadRequest) - Method in class alluxio.worker.netty.FileReadHandler
 
createRemoteGrpcDataServer(DataWorker) - Method in class alluxio.worker.DataServerFactory
 
createRequestContext(ReadRequest) - Method in class alluxio.worker.grpc.FileReadHandler
 
createRequestContext(WriteRequest) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
createRequestContext(Protocol.WriteRequest) - Method in class alluxio.worker.netty.FileWriteHandler
 
createRequestContext(Protocol.WriteRequest) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
createResponse(AlluxioStatusException) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response for a given AlluxioStatusException.
createResponse(Status, String, DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response for a given status, message, and data buffer.
createRpcContext() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createRpcContext(OperationContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createRpcExecutorService() - Method in class alluxio.master.AlluxioMasterProcess
 
createRpcExecutorService() - Method in class alluxio.master.MasterProcess
This method is decoupled from MasterProcess.createBaseRpcServer() because the AlluxioExecutorService needs to be managed (i.e.
createRpcId() - Static method in class alluxio.util.IdUtils
 
createSample(String, String, List<String>, List<String>, double) - Method in class alluxio.metrics.sink.RatisNameRewriteSampleBuilder
 
createSaslClientHandler(AuthType, Subject, AlluxioConfiguration) - Method in class alluxio.grpc.GrpcChannel
 
createSaslHandler(ChannelAuthenticationScheme) - Method in interface alluxio.security.authentication.AuthenticationServer
Creates server-side Sasl handler for given scheme.
createSaslHandler(ChannelAuthenticationScheme) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
Creates a SaslServer using the parameters supplied.
createScope() - Method in class alluxio.s3.signature.AwsCredential
 
createServerBuilder(String, SocketAddress, ChannelType) - Method in class alluxio.worker.grpc.GrpcDataServer
 
createServerErrorResponseEvent(AlluxioStatusException) - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
Create a ServerErrorResponseEvent.
createSessionId() - Static method in class alluxio.util.IdUtils
 
createSignatureBase(SignatureInfo, ContainerRequestContext) - Static method in class alluxio.s3.signature.StringToSignProducer
Convert signature info to strToSign.
createSignatureBase(SignatureInfo, HttpServletRequest) - Static method in class alluxio.s3.signature.StringToSignProducer
Convert signature info to strToSign.
createSignatureBase(SignatureInfo, HttpRequest) - Static method in class alluxio.s3.signature.StringToSignProducer
Convert signature info to strToSign.
createSignatureBase(SignatureInfo, String, String, String, Map<String, String>, Map<String, String>) - Static method in class alluxio.s3.signature.StringToSignProducer
Convert request info to strToSign.
createStorageDirPath(String, String) - Static method in class alluxio.util.io.FileUtils
Creates the storage directory path, including any necessary but nonexistent parent directories.
createStream(long, long) - Method in class alluxio.underfs.cos.COSInputStream
 
createStream(long, long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
Opens a new stream reading a range.
createStream(long, long) - Method in class alluxio.underfs.obs.OBSInputStream
 
createStream(long, long) - Method in class alluxio.underfs.oss.OSSInputStream
 
createSyncLockingScheme(AlluxioURI, FileSystemMasterCommonPOptions, DescendantType) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
createTempBlockMeta(long, long, long) - Method in interface alluxio.worker.block.meta.DirView
Creates a TempBlockMeta given sessionId, blockId, and initialBlockSize.
createThenDeleteExistingDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating and deleting existing directory.
createThenGetExistingDirectoryStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting existing directory status.
createThenGetExistingFileStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting existing file status.
createThenGetExistingStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting existing status.
createTimePredicate(String) - Method in class alluxio.master.predicate.TimePredicate.Factory
Creates a FilePredicate from the string value.
createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockStore
Creates a block reader to read a UFS block starting from given block offset.
createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Creates a block reader to read a UFS block starting from given block offset.
createUfsReadHeartBeatResponseEvent() - Method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
Create an UfsReadHeartBeatResponseEvent.
createUnstartedStopwatch() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
createUnstartedStopwatch() - Method in class alluxio.client.file.cache.LocalCachePositionReader
 
createUnusedMountId() - Method in class alluxio.master.file.meta.MountTable
Creates a mount point ID and guarantees uniqueness.
createUserProcessesLimitValidationTask() - Static method in class alluxio.cli.UserLimitValidationTask
Creates a validation task for checking whether the user limit for number of user processes is within reasonable range.
createWebServer() - Method in class alluxio.master.AlluxioJobMasterProcess
 
createWebServer() - Method in class alluxio.master.AlluxioMasterProcess
 
createWebServer() - Method in class alluxio.master.MasterProcess
 
createWithRecorder(String, UnderFileSystemConfiguration, Recorder) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates a client for operations involved with the under file system and record the execution process.
createWriteBatch() - Method in interface alluxio.master.metastore.InodeStore
Creates a write batch.
createWriteBatch() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
createZkJobPrimarySelector() - Static method in class alluxio.master.PrimarySelector.Factory
 
createZkPrimarySelector() - Static method in class alluxio.master.PrimarySelector.Factory
 
CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
CREATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
CREATIONTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
CREDENTIAL_FIELD_MASKER - Static variable in class alluxio.RpcSensitiveConfigMask
 
CredentialPropertyKeys - Class in alluxio.conf
This class stores names of property keys whose values are credential.
CredentialPropertyKeys() - Constructor for class alluxio.conf.CredentialPropertyKeys
 
CronExpressionIntervalSupplier - Class in alluxio.heartbeat
Calculate the next interval by given cron expression.
CronExpressionIntervalSupplier(CronExpression, long) - Constructor for class alluxio.heartbeat.CronExpressionIntervalSupplier
CROSS_CLUSTER_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
CROSS_CLUSTER_MASTER_CLIENT_SERVICE = 1004;
CSV_FILE_HEADER - Static variable in class alluxio.cli.docgen.ConfigurationDocGenerator
 
CsvSink - Class in alluxio.metrics.sink
A sink which creates a CSV file of the metric values.
CsvSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.CsvSink
Creates a new CsvSink with a Properties and MetricRegistry.
CuckooTable - Interface in alluxio.client.file.cache.cuckoofilter
The cuckoo table that supports to store and access data positioned by a specific bucket and slot.
CuckooUtils - Class in alluxio.client.file.cache.cuckoofilter
This class provides some useful methods for cuckoo filters.
CuckooUtils() - Constructor for class alluxio.client.file.cache.cuckoofilter.CuckooUtils
 
CUR_DIR - Static variable in class alluxio.AlluxioURI
 
CURRENT_VERSION_INFO - Static variable in class alluxio.RuntimeConstants
 
CURRENTBLOCKS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
CURRENTBLOCKSONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
CurrentUser - Class in alluxio.security
This class represents the current user, which represents the end user.
CurrentUser(String) - Constructor for class alluxio.security.CurrentUser
Constructs a new user with a name.
CurrentUser(String, String) - Constructor for class alluxio.security.CurrentUser
Constructs a new user with a name and a service name.
CUSTOM_EXCEPTION_MESSAGE - Static variable in exception alluxio.exception.BusyException
 
CUSTOM_VALUE - Static variable in enum alluxio.grpc.ChannelAuthenticationScheme
CUSTOM = 2;
CustomAuthenticationProvider - Class in alluxio.security.authentication.plain
An authentication provider implementation that allows AuthenticationProvider to be customized at configuration time.
CustomAuthenticationProvider(Class<?>) - Constructor for class alluxio.security.authentication.plain.CustomAuthenticationProvider
Constructs a new custom authentication provider.
CustomAuthPolicy - Class in alluxio.fuse.auth
A Fuse authentication policy supports user-defined user and group.

D

DailyMetadataBackup - Class in alluxio.master.meta
Backing up primary master metadata everyday at a fixed UTC time.
Data() - Constructor for class alluxio.stress.graph.BarGraph.Data
Creates an instance.
Data() - Constructor for class alluxio.stress.graph.LineGraph.Data
Creates an instance.
DATA_CACHE_DIRS_OPTION_NAME - Static variable in class alluxio.fuse.options.MountOptions
 
DATA_CACHE_SIZES_OPTION_NAME - Static variable in class alluxio.fuse.options.MountOptions
 
DATA_COLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
DATA_FIELD_NUMBER - Static variable in class alluxio.grpc.Chunk
 
DATA_FIELD_NUMBER - Static variable in class alluxio.grpc.Command
 
DATA_FIELD_NUMBER - Static variable in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
DATA_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsInfo
 
DATA_FIELD_NUMBER - Static variable in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
DATA_LOSS_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
DataLoss indicates unrecoverable data loss or corruption.
Database - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Database
Database.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Database
DATABASE_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
DATABASE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetAllDatabasesPResponse
 
DATABASE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetAllTablesPRequest
 
DATABASE_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
DatabaseOrBuilder - Interface in alluxio.grpc.table
 
DatabaseValidationTask - Class in alluxio.cli.hms
A task which, given a metastore client can retrieve information from a user-specified database.
DatabaseValidationTask(String, MetastoreValidationTask<?, IMetaStoreClient>) - Constructor for class alluxio.cli.hms.DatabaseValidationTask
Create a new instance of DatabaseValidationTask.
DataBlockIndexType - Enum in alluxio.master.metastore.rocks
DataBlockIndexType used in conjunction with BlockBasedTable.
DataBuffer - Interface in alluxio.network.protocol.databuffer
This interface is a simple wrapper for the optional data that an RPCMessage may have.
DataFileChannel - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a FileChannel.
DataFileChannel(File, long, long) - Constructor for class alluxio.network.protocol.databuffer.DataFileChannel
 
DataLossException - Exception in alluxio.exception.status
Exception indicating unrecoverable data loss or corruption.
DataLossException(String) - Constructor for exception alluxio.exception.status.DataLossException
 
DataLossException(Throwable) - Constructor for exception alluxio.exception.status.DataLossException
 
DataLossException(String, Throwable) - Constructor for exception alluxio.exception.status.DataLossException
 
DataMessage<T,R> - Class in alluxio.grpc
A struct that carries a message with a data buffer.
DataMessage(T, R) - Constructor for class alluxio.grpc.DataMessage
 
DataMessageClientResponseObserver<ReqT,RespT> - Class in alluxio.client.block.stream
A StreamObserver that handles raw data buffers.
DataMessageClientResponseObserver(StreamObserver<RespT>, DataMessageMarshaller<ReqT>, DataMessageMarshaller<RespT>) - Constructor for class alluxio.client.block.stream.DataMessageClientResponseObserver
 
DataMessageMarshaller<T> - Class in alluxio.grpc
Marshaller for data messages.
DataMessageMarshaller(MethodDescriptor.Marshaller<T>) - Constructor for class alluxio.grpc.DataMessageMarshaller
Creates a data marshaller.
DataMessageMarshallerProvider<ReqT,ResT> - Class in alluxio.grpc
A provider of DataMessageMarshaller for a gRPC call.
DataMessageMarshallerProvider(DataMessageMarshaller<ReqT>, DataMessageMarshaller<ResT>) - Constructor for class alluxio.grpc.DataMessageMarshallerProvider
 
DataMessageServerRequestObserver<ReqT,ResT> - Class in alluxio.worker.grpc
A StreamObserver that handles raw data buffers.
DataMessageServerRequestObserver(StreamObserver<ResT>, DataMessageMarshaller<ReqT>, DataMessageMarshaller<ResT>) - Constructor for class alluxio.worker.grpc.DataMessageServerRequestObserver
 
DataMessageServerStreamObserver<T> - Class in alluxio.worker.grpc
A StreamObserver for handling raw data buffers.
DataMessageServerStreamObserver(CallStreamObserver<T>, BufferRepository<T, DataBuffer>) - Constructor for class alluxio.worker.grpc.DataMessageServerStreamObserver
 
DataPoint(double) - Constructor for class alluxio.metrics.TimeSeries.DataPoint
Construct a new data point with the current time as the timestamp.
DATAPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
 
DataReader - Interface in alluxio.client.block.stream
The interface to read data chunks.
DataReader.Factory - Interface in alluxio.client.block.stream
The factory interface to create DataReaders.
DataResponseEvent - Class in alluxio.client.file.dora.netty.event
Data response event.
DataResponseEvent(ByteBuf) - Constructor for class alluxio.client.file.dora.netty.event.DataResponseEvent
Data response event.
DataServer - Interface in alluxio.worker
Defines how to interact with a server running the data protocol.
DataServerFactory - Class in alluxio.worker
Factory for data server.
DataServerFactory(UfsManager, InetSocketAddress, InetSocketAddress) - Constructor for class alluxio.worker.DataServerFactory
 
dataSizeBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
DataWorker - Interface in alluxio.worker
A Worker for caching data.
DataWriter - Interface in alluxio.client.block.stream
The interface to write data.
DataWriter.Factory - Class in alluxio.client.block.stream
Factory for DataWriter.
Date - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Date
Date.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Date
DATE_FORMATTER - Static variable in class alluxio.s3.S3Constants
 
DATE_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
DateColumnStatsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DateColumnStatsData
DateColumnStatsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DateColumnStatsData
DateColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
 
DateFromFileNameOlderThanFactory() - Constructor for class alluxio.master.predicate.TimePredicate.DateFromFileNameOlderThanFactory
 
DateOrBuilder - Interface in alluxio.grpc.table
 
DatePredicate - Class in alluxio.master.predicate
A predicate related to date of the file.
DatePredicate(String, String, Function<FileInfo, Long>) - Constructor for class alluxio.master.predicate.DatePredicate
Creates an instance.
DatePredicate.Factory - Class in alluxio.master.predicate
Factory for creating instances.
DatePredicate.LastModifiedDateFactory - Class in alluxio.master.predicate
Factory for modification time predicate.
DATETIME_FORMAT - Static variable in class alluxio.cli.fsadmin.report.ProxyCommand
 
DATETIME_FORMAT - Static variable in class alluxio.ProcessUtils
 
DAY - Static variable in class alluxio.Constants
 
DAY_MS - Static variable in class alluxio.Constants
 
DAYS_SINCE_EPOCH_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Date
 
Db() - Constructor for class alluxio.dora.meta.DoraMetaBench.Db
 
Db() - Constructor for class alluxio.inode.InodeBenchRead.Db
 
Db() - Constructor for class alluxio.inode.InodeBenchWrite.Db
 
Db() - Constructor for class alluxio.inode.RocksBenchRead.Db
 
Db() - Constructor for class alluxio.inode.RocksBenchReadWrite.Db
 
Db() - Constructor for class alluxio.inode.RocksBenchWrite.Db
 
DB_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetDatabasePResponse
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DetachDatabasePRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetDatabasePRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTablePRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ReadTablePRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncDatabasePRequest
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformJobInfo
 
DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformTablePRequest
 
DEADLINE_EXCEEDED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
DeadlineExceeded means operation expired before completion.
DeadlineExceededException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
DeadlineExceededException(String) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededException(Throwable) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededException(String, Throwable) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that an operation expired before completion.
DeadlineExceededRuntimeException(String) - Constructor for exception alluxio.exception.runtime.DeadlineExceededRuntimeException
Constructor.
DEAFULT_FUSE_MOUNT - Static variable in class alluxio.Constants
 
deallocate() - Method in class alluxio.network.protocol.databuffer.PooledDirectNioByteBuf
 
DEBUG - Static variable in class alluxio.conf.PropertyKey
 
DEBUG - Static variable in class alluxio.conf.PropertyKey.Name
 
debug(String) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
DebugLoggingTracer<S,T> - Class in alluxio.client.file.dora.netty
A tracer that logs every trigger and state transition to the debug level.
DebugLoggingTracer(Logger) - Constructor for class alluxio.client.file.dora.netty.DebugLoggingTracer
Constructor.
dec(int) - Method in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
Decrements the size from the encoder.
dec() - Method in class alluxio.concurrent.CountingLatch
Decreases the counter.
Decimal - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Decimal
Decimal.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Decimal
DECIMAL_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
DecimalColumnStatsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DecimalColumnStatsData
DecimalColumnStatsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DecimalColumnStatsData
DecimalColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
 
DecimalOrBuilder - Interface in alluxio.grpc.table
 
decode(byte[]) - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
Decode an object from a single byte string.
decode(ByteBuf) - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns the type represented by the id from the input ByteBuf.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class alluxio.network.protocol.RPCMessageDecoder
 
decode(ByteBuf, ProtoMessage) - Static method in class alluxio.network.protocol.RPCProtoMessage
Decodes the message from a buffer.
decodeMessage(RPCMessage.Type, ByteBuf) - Static method in class alluxio.network.protocol.RPCMessage
Returns the message of message type 'type', decoded from the input ByteBuf.
decodeToken(String) - Static method in class alluxio.s3.ListBucketResult
Decode a continuation token which is used in get Bucket.
decommission(WorkerInfo) - Method in class alluxio.membership.EtcdMembershipManager
 
decommission(WorkerInfo) - Method in class alluxio.membership.MasterMembershipManager
 
decommission(WorkerInfo) - Method in interface alluxio.membership.MembershipManager
Decommision a worker.
decommission(WorkerInfo) - Method in class alluxio.membership.StaticMembershipManager
 
DECOMMISSIONED_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
Decommissioned_VALUE - Static variable in enum alluxio.grpc.CommandType
Notify the worker that it has been decommissioned
DECOMMISSIONED_VALUE - Static variable in enum alluxio.grpc.WorkerRange
DECOMMISSIONED = 5;
DECOMMISSIONED_WORKER_NUM_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
DECOMMISSIONED_WORKER_NUM = 8;
DECOMMISSIONEDWORKERNUM_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
decommissionWorker(DecommissionWorkerPOptions) - Method in interface alluxio.client.block.BlockMasterClient
Decommission a worker.
decommissionWorker(DecommissionWorkerPOptions) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
decommissionWorker(DecommissionWorkerPOptions, StreamObserver<DecommissionWorkerPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Decommission the specific worker from Alluxio.
decommissionWorker(DecommissionWorkerPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Decommission the specific worker from Alluxio.
decommissionWorker(DecommissionWorkerPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Decommission the specific worker from Alluxio.
decommissionWorker(DecommissionWorkerPOptions, StreamObserver<DecommissionWorkerPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Decommission the specific worker from Alluxio.
decommissionWorker(DecommissionWorkerPOptions) - Method in interface alluxio.master.block.BlockMaster
Decommission a worker.
decommissionWorker(DecommissionWorkerPOptions, StreamObserver<DecommissionWorkerPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
decommissionWorker(DecommissionWorkerPOptions) - Method in class alluxio.master.block.DefaultBlockMaster
 
DecommissionWorkerCommand - Class in alluxio.cli.fsadmin.command
Decommission a specific batch of workers, the decommissioned worker is not automatically shutdown and will not be picked for new I/O requests.
DecommissionWorkerCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
Constructs a new instance to decommission a given batch of workers from Alluxio.
DecommissionWorkerCommand.ReturnCode - Enum in alluxio.cli.fsadmin.command
A set of return codes.
DecommissionWorkerCommand.WorkerStatus - Class in alluxio.cli.fsadmin.command
A wrapper managing worker activeness status and deciding whether the worker can be safely killed.
DecommissionWorkerPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.DecommissionWorkerPOptions
DecommissionWorkerPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.DecommissionWorkerPOptions
DecommissionWorkerPOptionsOrBuilder - Interface in alluxio.grpc
 
DecommissionWorkerPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.DecommissionWorkerPResponse
DecommissionWorkerPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.DecommissionWorkerPResponse
DecommissionWorkerPResponseOrBuilder - Interface in alluxio.grpc
 
decompress(String, File) - Static method in class alluxio.cli.bundler.TarUtils
Decompresses a tarball to one destination.
decompress(Path, String, int) - Static method in class alluxio.util.compression.ParallelZipUtils
Reads a zipped archive from a path in parallel and writes it to the given path.
decrementPendingCountUnlessZero() - Method in class alluxio.concurrent.jsr.CountedCompleter
If the pending count is nonzero, (atomically) decrements it.
DEFAULT - Static variable in class alluxio.conf.Source
 
DEFAULT_ACL_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
DEFAULT_ACTIVE_JOBS - Static variable in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
DEFAULT_ACTIVE_JOBS - Static variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
DEFAULT_DATABASE - Static variable in class alluxio.cli.HmsValidationTool
 
DEFAULT_ENCODING_TYPE - Static variable in class alluxio.s3.ListBucketOptions
 
DEFAULT_FILE_COUNT - Static variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
DEFAULT_FILE_SYSTEM_MODE - Static variable in class alluxio.Constants
 
DEFAULT_FILE_SYSTEM_UMASK - Static variable in class alluxio.Constants
 
DEFAULT_FPP - Static variable in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
DEFAULT_LEASE_TTL_IN_SEC - Static variable in class alluxio.membership.AlluxioEtcdClient
 
DEFAULT_LOAD_FACTOR - Static variable in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
DEFAULT_MAX_KEYS - Static variable in class alluxio.s3.ListBucketOptions
 
DEFAULT_REGISTRY_GET_TIMEOUT_MS - Static variable in class alluxio.Constants
 
DEFAULT_RETRY_ATTEMPTS - Static variable in class alluxio.master.file.meta.TtlBucket
 
DEFAULT_SOCKET_TIMEOUT_MINUTES - Static variable in class alluxio.cli.HmsValidationTool
 
DEFAULT_TASK_ID - Static variable in class alluxio.stress.BaseParameters
 
DEFAULT_TIMEOUT_IN_SEC - Static variable in class alluxio.membership.AlluxioEtcdClient
 
DefaultAccessControlList - Class in alluxio.security.authorization
Default Access control list for a directory.
DefaultAccessControlList() - Constructor for class alluxio.security.authorization.DefaultAccessControlList
Constructor to build a default ACL that is empty.
DefaultAccessControlList(AccessControlList) - Constructor for class alluxio.security.authorization.DefaultAccessControlList
Constructor to build a default ACL based on an access ACL.
DEFAULTACL_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
DEFAULTACL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
DEFAULTACL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
DefaultAsyncPersistHandler - Class in alluxio.master.file.async
The default handler for async persistence that schedules the persistence on the workers that contains all the blocks of a given file, and the handler returns the scheduled request whenever the corresponding worker polls.
DefaultAsyncPersistHandler(FileSystemMasterView) - Constructor for class alluxio.master.file.async.DefaultAsyncPersistHandler
Constructs a new instance of AsyncPersistHandler.
DefaultAuthenticationServer - Class in alluxio.security.authentication
Default implementation of AuthenticationServer.
DefaultAuthenticationServer(String, AlluxioConfiguration) - Constructor for class alluxio.security.authentication.DefaultAuthenticationServer
Creates DefaultAuthenticationServer instance.
DefaultBlockDeletionContext - Class in alluxio.master.file
Class for tracking which blocks need to be deleted, and deleting them on close.
DefaultBlockDeletionContext(BlockDeletionContext.BlockDeletionListener...) - Constructor for class alluxio.master.file.DefaultBlockDeletionContext
 
DefaultBlockMaster - Class in alluxio.master.block
This block master manages the metadata for all the blocks and block workers in Alluxio.
DefaultBlockMaster(MetricsMaster, CoreMasterContext, Clock, ExecutorServiceFactory) - Constructor for class alluxio.master.block.DefaultBlockMaster
Creates a new instance of DefaultBlockMaster.
DefaultBlockMaster.LostWorkerDetectionHeartbeatExecutor - Class in alluxio.master.block
Lost worker periodic check.
DefaultBlockMaster.Metrics - Class in alluxio.master.block
Class that contains metrics related to BlockMaster.
DefaultBlockMaster.WorkerRegisterStreamGCExecutor - Class in alluxio.master.block
Periodically checks the open worker register streams.
DefaultBlockMasterContainerIdJournaled - Class in alluxio.master.block
Writes a single journal - essential to the DefaultBlockMaster - entry to a checkpoint.
DefaultBlockMasterContainerIdJournaled() - Constructor for class alluxio.master.block.DefaultBlockMasterContainerIdJournaled
 
DefaultBlockWorkerClient - Class in alluxio.client.block.stream
Default implementation of BlockWorkerClient.
DefaultBlockWorkerClient(UserState, GrpcServerAddress, AlluxioConfiguration) - Constructor for class alluxio.client.block.stream.DefaultBlockWorkerClient
Creates a client instance for communicating with block worker.
DefaultBlockWorkerClient(UserState, GrpcServerAddress, AlluxioConfiguration, GrpcChannel, GrpcChannel) - Constructor for class alluxio.client.block.stream.DefaultBlockWorkerClient
 
DefaultBlockWorkerClient.NoDataReadStreamObserver - Class in alluxio.client.block.stream
No data read stream observer.
DefaultCacheFilter - Class in alluxio.client.file.cache.filter
Default Cache Filter cache everything.
DefaultCacheFilter(AlluxioConfiguration, String) - Constructor for class alluxio.client.file.cache.filter.DefaultCacheFilter
The default constructor.
defaultClientRetry() - Static method in class alluxio.retry.RetryUtils
Gives a default ClientRetry based on config.
defaultExecutor() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the default Executor used for async methods that do not specify an Executor.
DefaultFileSystemMaster - Class in alluxio.master.file
The master that handles all file system metadata management.
DefaultFileSystemMaster(BlockMaster, CoreMasterContext) - Constructor for class alluxio.master.file.DefaultFileSystemMaster
Creates a new instance of DefaultFileSystemMaster.
DefaultFileSystemMaster(BlockMaster, CoreMasterContext, ExecutorServiceFactory, Clock) - Constructor for class alluxio.master.file.DefaultFileSystemMaster
Creates a new instance of DefaultFileSystemMaster.
DefaultFileSystemMaster.Metrics - Class in alluxio.master.file
Class that contains metrics for FileSystemMaster.
DefaultFileSystemMaster.Metrics.UFSOps - Enum in alluxio.master.file
UFS operations enum.
defaultForkJoinWorkerThreadFactory - Static variable in class alluxio.concurrent.jsr.ForkJoinPool
Creates a new ForkJoinWorkerThread.
DefaultJournalMaster - Class in alluxio.master.journal
Default implementation for JournalMaster.
DefaultJournalMaster(JournalDomain, MasterContext) - Constructor for class alluxio.master.journal.DefaultJournalMaster
 
defaultKeys() - Static method in class alluxio.conf.PropertyKey
 
DefaultMetaMaster - Class in alluxio.master.meta
The default meta master.
DefaultMetaMaster.State - Class in alluxio.master.meta
Journaled state for MetaMaster.
DefaultMetricsMaster - Class in alluxio.master.metrics
Default implementation of the metrics master.
defaultOptions() - Static method in class alluxio.resource.DynamicResourcePool.Options
 
DefaultPageMetaStore - Class in alluxio.client.file.cache
The default implementation of a metadata store for pages stored in cache.
DefaultPageMetaStore(List<PageStoreDir>) - Constructor for class alluxio.client.file.cache.DefaultPageMetaStore
 
DefaultPageMetaStore(List<PageStoreDir>, Allocator) - Constructor for class alluxio.client.file.cache.DefaultPageMetaStore
Constructor of DefaultMetaStore.
DefaultPermissionChecker - Class in alluxio.master.file
Default implementation of permission checker.
DefaultPermissionChecker(InodeTree) - Constructor for class alluxio.master.file.DefaultPermissionChecker
Constructs a PermissionChecker instance for Alluxio file system.
defaults() - Static method in class alluxio.client.block.options.GetWorkerReportOptions
 
defaults() - Static method in class alluxio.client.file.CacheContext
 
defaults(FileSystemContext, AlluxioConfiguration) - Static method in class alluxio.client.file.options.OutStreamOptions
 
defaults(FileSystemContext) - Static method in class alluxio.client.file.options.OutStreamOptions
 
defaults() - Static method in class alluxio.conf.ConfigurationValueOptions
 
defaults() - Static method in class alluxio.master.file.contexts.CheckAccessContext
 
defaults() - Static method in class alluxio.master.file.contexts.CheckConsistencyContext
 
defaults() - Static method in class alluxio.master.file.contexts.CompleteFileContext
 
defaults() - Static method in class alluxio.master.file.contexts.CreateDirectoryContext
 
defaults() - Static method in class alluxio.master.file.contexts.CreateFileContext
 
defaults() - Static method in class alluxio.master.file.contexts.DeleteContext
 
defaults() - Static method in class alluxio.master.file.contexts.ExistsContext
 
defaults() - Static method in class alluxio.master.file.contexts.FreeContext
 
defaults() - Static method in class alluxio.master.file.contexts.GetStatusContext
 
defaults() - Static method in class alluxio.master.file.contexts.ListStatusContext
 
defaults() - Static method in class alluxio.master.file.contexts.LoadMetadataContext
 
defaults() - Static method in class alluxio.master.file.contexts.MountContext
 
defaults() - Static method in class alluxio.master.file.contexts.RenameContext
 
defaults() - Static method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
 
defaults() - Static method in class alluxio.master.file.contexts.SetAclContext
 
defaults() - Static method in class alluxio.master.file.contexts.SetAttributeContext
 
defaults() - Static method in class alluxio.master.file.contexts.WorkerHeartbeatContext
 
defaults() - Static method in class alluxio.master.journal.options.JournalReaderOptions
 
defaults() - Static method in class alluxio.master.journal.options.JournalWriterOptions
 
defaults() - Static method in class alluxio.master.metastore.ReadOption
 
defaults() - Static method in class alluxio.master.StateLockOptions
This default instance is effectively the same as locking on write-lock.
defaults() - Static method in class alluxio.network.netty.NettyRPCContext
 
defaults() - Static method in class alluxio.s3.ListBucketOptions
Creates a default ListBucketOptions.
defaults() - Static method in class alluxio.security.authorization.Mode
Gets the default mode.
defaults(AlluxioConfiguration) - Static method in class alluxio.underfs.options.CreateOptions
 
defaults() - Static method in class alluxio.underfs.options.DeleteOptions
 
defaults() - Static method in class alluxio.underfs.options.FileLocationOptions
 
defaults() - Static method in class alluxio.underfs.options.GetStatusOptions
 
defaults() - Static method in class alluxio.underfs.options.ListOptions
 
defaults(AlluxioConfiguration) - Static method in class alluxio.underfs.options.MkdirsOptions
 
defaults() - Static method in class alluxio.underfs.options.OpenOptions
 
defaults(AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystemConfiguration
 
defaults() - Static method in class alluxio.util.WaitForOptions
 
DefaultSafeModeManager - Class in alluxio.master
Manages safe mode state for Alluxio master.
DefaultSafeModeManager() - Constructor for class alluxio.master.DefaultSafeModeManager
Creates DefaultSafeModeManager with default clock.
DefaultSafeModeManager(Clock) - Constructor for class alluxio.master.DefaultSafeModeManager
Creates DefaultSafeModeManager with given clock.
DefaultServiceEntity - Class in alluxio.membership
Base Entity class including information to register to Etcd when using EtcdMembershipManager.
DefaultServiceEntity() - Constructor for class alluxio.membership.DefaultServiceEntity
CTOR for DefaultServiceEntity.
DefaultServiceEntity(String) - Constructor for class alluxio.membership.DefaultServiceEntity
CTOR for ServiceEntity with given ServiceEntity name.
defaultsForDailyBackup() - Static method in class alluxio.master.StateLockOptions
 
defaultsForShellBackup() - Static method in class alluxio.master.StateLockOptions
 
DefaultSslContextProvider - Class in alluxio.util.network.tls
Default SSL context provider.
DefaultSslContextProvider() - Constructor for class alluxio.util.network.tls.DefaultSslContextProvider
 
DefaultStorageTierAssoc - Class in alluxio
Creates a two-way mapping between storage tier aliases and ordinal numbers from the given Configuration.
DefaultStorageTierAssoc(PropertyKey, PropertyKey.Template) - Constructor for class alluxio.DefaultStorageTierAssoc
Constructs a new instance using the given Configuration object.
DefaultStorageTierAssoc(List<String>) - Constructor for class alluxio.DefaultStorageTierAssoc
Constructs a new instance using the given list of storage tier aliases in order of their position in the hierarchy.
DefaultSupplier - Class in alluxio
Supplier for a configuration property default.
DefaultSupplier(Supplier<Object>, String) - Constructor for class alluxio.DefaultSupplier
 
defaultWorkerMasterClientRetry() - Static method in class alluxio.retry.RetryUtils
 
DefaultWorkerProvider - Class in alluxio.master.scheduler
Default worker provider that get worker information from Alluxio master.
DefaultWorkerProvider(FileSystemMaster, FileSystemContext) - Constructor for class alluxio.master.scheduler.DefaultWorkerProvider
Creates a new instance of DefaultWorkerProvider.
defined() - Method in enum alluxio.jnifuse.constants.Errno
 
DEFINITION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Transformation
 
DEFINITION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformJobInfo
 
DEFINITION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformTablePRequest
 
delayBaseline(RpcUtilsBench.BenchParams) - Method in class alluxio.RpcUtilsBench
 
delayedExecutor(long, TimeUnit, Executor) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new Executor that submits a task to the given base executor after the given delay (or no delay if non-positive).
delayedExecutor(long, TimeUnit) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new Executor that submits a task to the default executor after the given delay (or no delay if non-positive).
DelayNode(T, long) - Constructor for class alluxio.util.executor.ControllableQueue.DelayNode
Constructs a new ControllableQueue.DelayNode.
DelegatingFileSystem - Class in alluxio.client.file
A wrapper of a FileSystem instance.
DelegatingFileSystem(FileSystem) - Constructor for class alluxio.client.file.DelegatingFileSystem
Wraps a file system instance to forward messages.
DelegatingJournaled - Interface in alluxio.master.journal
Convenient interface for classes which delegate their journaling methods to another journaled object.
DelegatingReadOnlyInodeStore - Class in alluxio.master.metastore
Wrapper for providing read-only access to an inode store.
DelegatingReadOnlyInodeStore(InodeStore) - Constructor for class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
DelegatingSet<T> - Class in alluxio.collections
A set which delegates all methods to another set.
DelegatingSet(Set<T>) - Constructor for class alluxio.collections.DelegatingSet
 
delete(DeletePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Delete a file from.
delete(DeletePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
delete(PageId) - Method in interface alluxio.client.file.cache.CacheManager
Deletes a page from the cache.
delete(PageId) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
delete(PageId) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
delete(T) - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
Delete an item from cuckoo filter.
delete(T) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
delete(PageId, boolean) - Method in class alluxio.client.file.cache.LocalCacheManager
delete the specified page.
delete(PageId) - Method in class alluxio.client.file.cache.LocalCacheManager
 
delete(PageId) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
delete(PageId) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
delete(PageId, boolean) - Method in interface alluxio.client.file.cache.PageStore
Deletes a temporary page from the store.
delete(PageId) - Method in interface alluxio.client.file.cache.PageStore
Deletes a page from the store.
delete(PageId) - Method in interface alluxio.client.file.cache.ShadowCacheManager
Deletes a page from the cache.
delete(PageId, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
delete(PageId) - Method in class alluxio.client.file.cache.store.MemoryPageStore
 
delete(PageId) - Method in class alluxio.client.file.cache.TimeBoundPageStore
 
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
delete(String, DeletePOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Delete a file.
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
delete(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.delete(AlluxioURI, DeletePOptions) with default options.
delete(AlluxioURI, DeletePOptions) - Method in interface alluxio.client.file.FileSystem
Deletes a file or a directory.
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
delete(AlluxioURI, DeletePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Deletes a file or a directory.
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
delete(AlluxioURI, DeletePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
delete(Path) - Method in class alluxio.hadoop.AbstractFileSystem
delete(Path, boolean) - Method in class alluxio.hadoop.AbstractFileSystem
Attempts to delete the file or directory with the specified path.
delete(Path, boolean) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
Delete - Class in alluxio.master.backcompat.ops
Test for file deletion.
Delete() - Constructor for class alluxio.master.backcompat.ops.Delete
 
delete(AlluxioURI, DeleteContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
delete(AlluxioURI, DeleteContext) - Method in interface alluxio.master.file.FileSystemMaster
Deletes a given path.
delete(Supplier<JournalContext>, AlluxioURI, boolean) - Method in class alluxio.master.file.meta.MountTable
Unmounts the given Alluxio path.
delete(AlluxioURI, Inode) - Method in class alluxio.master.file.NoopUfsDeleter
 
delete(AlluxioURI, Inode) - Method in class alluxio.master.file.SafeUfsDeleter
 
delete(AlluxioURI, Inode) - Method in interface alluxio.master.file.UfsDeleter
Deletes a path if not covered by a recursive delete.
DELETE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
delete(String, DeletePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
delete(String) - Static method in class alluxio.util.io.FileUtils
Deletes the file or directory.
delete(String, DeletePOptions) - Method in interface alluxio.worker.dora.DoraWorker
Delete a file.
delete(String, DeletePOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
delete(AlluxioURI, FileSystem) - Static method in class alluxio.worker.task.DeleteHandler
This function deletes files/directories.
DELETE_ALLUXIO_VALUE - Static variable in enum alluxio.grpc.TtlAction
Delete the data and metadata in Alluxio after TTL expires.
DELETE_ALLUXIO_VALUE - Static variable in enum alluxio.proto.journal.File.PTtlAction
DELETE_ALLUXIO = 2;
DELETE_BLOCK_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
DELETE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
DELETE_KEYS_VALUE - Static variable in enum alluxio.proto.journal.File.XAttrUpdateStrategy
DELETE_KEYS = 4;
DELETE_MOUNT_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
Delete_VALUE - Static variable in enum alluxio.grpc.CommandType
Ask the worker to delete files.
DELETE_VALUE - Static variable in enum alluxio.grpc.TtlAction
Delete the file after TTL expires.
DELETE_VALUE - Static variable in enum alluxio.proto.journal.File.PTtlAction
DELETE = 0;
deleteBucket(String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Deletes a bucket, or deletes all tags from an existing bucket.
DeleteBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
Construct a new ObjectUnderFileSystem.DeleteBuffer instance.
deleteCompletedLogs() - Method in interface alluxio.master.journalv0.JournalWriter
Deletes all of the completed logs.
deleteCompletedLogs() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
DeleteContext - Class in alluxio.master.file.contexts
Used to merge and wrap DeletePOptions.
deleteDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
deleteDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
 
deleteDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteDirectory(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name non-recursively.
deleteDirectory(String, DeleteOptions) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name.
deleteDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteDirIfExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Deletes the directory at the given path if it exists.
deleteDirTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for deleting directory.
DeletedObject() - Constructor for class alluxio.s3.DeleteObjectsResult.DeletedObject
deleteExistingDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteExistingDirectory(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
deleteExistingDirectory(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteExistingDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system.
deleteExistingDirectory(String, DeleteOptions) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name.
deleteExistingDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteExistingFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteExistingFile(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
deleteExistingFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteExistingFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a file from the under file system with the indicated name.
deleteExistingFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteExistObject(FileSystem, AlluxioURI) - Static method in class alluxio.proxy.s3.S3RestUtils
Delete an existing key.
deleteExistObject(FileSystem, AlluxioURI, Boolean) - Static method in class alluxio.proxy.s3.S3RestUtils
Delete an existing key.
deleteFile(String) - Method in interface alluxio.client.file.cache.CacheManager
Deletes all pages of the given file.
deleteFile(String) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
deleteFile(String) - Method in class alluxio.client.file.cache.LocalCacheManager
 
deleteFile(String) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
deleteFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteFile(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
deleteFile(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
deleteFile(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
deleteFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a file from the under file system with the indicated name.
deleteFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteFileIfExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Deletes the specified path from the specified under file system if it is a file and exists.
deleteFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for deleting file.
deleteForPath(String, boolean) - Method in class alluxio.membership.AlluxioEtcdClient
Delete a path or recursively all paths with given path as prefix.
DeleteHandler - Class in alluxio.worker.task
DeleteHandler is responsible for deleting files.
DeleteHandler() - Constructor for class alluxio.worker.task.DeleteHandler
 
deleteIfExists(String) - Static method in class alluxio.util.io.FileUtils
Deletes the file or directory, if it exists.
deleteInode(RpcContext, LockedInodePath, long) - Method in class alluxio.master.file.meta.InodeTree
Deletes a single inode from the inode tree by removing it from the parent inode.
deleteInternal(RpcContext, LockedInodePath, DeleteContext, boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
Implements file deletion.
deleteLargeDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for deleting large directory.
deleteLeaf(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Deletes a leaf DAG node that carries the given payload.
DELETEMOUNTPOINT_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
 
DeleteObject() - Constructor for class alluxio.s3.DeleteObjectsRequest.DeleteObject
Default constructor for jackson.
DeleteObject(String) - Constructor for class alluxio.s3.DeleteObjectsRequest.DeleteObject
 
deleteObject(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to delete a key.
deleteObject(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
deleteObject(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
deleteObjectOrAbortMultipartUpload(String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Deletes an object, an object's tags, or aborts a multipart upload.
deleteObjects(List<String>) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
deleteObjects(List<String>) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to delete a list of keys.
deleteObjects(List<String>) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
deleteObjects(List<String>) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
deleteObjects(List<String>) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
DeleteObjectsRequest - Class in alluxio.s3
Parsed version of a request to DeleteObjects.
DeleteObjectsRequest() - Constructor for class alluxio.s3.DeleteObjectsRequest
Default constructor for jackson.
DeleteObjectsRequest(boolean, List<DeleteObjectsRequest.DeleteObject>) - Constructor for class alluxio.s3.DeleteObjectsRequest
Create a new DeleteObjectsRequest.
DeleteObjectsRequest.DeleteObject - Class in alluxio.s3
Inner POJO representing an object to delete in the S3 API.
DeleteObjectsResult - Class in alluxio.s3
An object representing the response to a DeleteObjects request.
DeleteObjectsResult() - Constructor for class alluxio.s3.DeleteObjectsResult
 
DeleteObjectsResult.DeletedObject - Class in alluxio.s3
An object representing Deleted result in DeleteObjects result.
DeleteObjectsResult.ErrorObject - Class in alluxio.s3
An object representing error result in DeleteObjects result.
DeleteOptions - Class in alluxio.underfs.options
Method options for deleting a directory in UnderFileSystem.
deletePage(PageInfo) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
deletePath(FileSystem, AlluxioURI) - Static method in class alluxio.fuse.AlluxioFuseUtils
Deletes a file or a directory in alluxio namespace.
deletePathRecursively(String) - Static method in class alluxio.util.io.FileUtils
Deletes a file or a directory, recursively if it is a directory.
DeletePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.DeletePOptions
DeletePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.DeletePOptions
DeletePOptionsOrBuilder - Interface in alluxio.grpc
 
DeletePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.DeletePRequest
DeletePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.DeletePRequest
DeletePRequestOrBuilder - Interface in alluxio.grpc
 
DeletePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.DeletePResponse
DeletePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.DeletePResponse
DeletePResponseOrBuilder - Interface in alluxio.grpc
 
deleteTag(int, int) - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
Delete a tag in specified bucket and return its position.
deleteTag(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
deleteTempFile(String) - Method in interface alluxio.client.file.cache.CacheManager
Deletes all temporary pages of the given file.
deleteTempFile(String) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
deleteTempFile(String) - Method in class alluxio.client.file.cache.LocalCacheManager
 
deleteTempFile(String) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
deleteTempPage(PageInfo) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
DELIMITER - Static variable in class alluxio.master.job.tracker.CmdJobTracker
 
DemoProperty - Class in alluxio.conf.reference
This class is used to demo the reference properties.
DemoProperty() - Constructor for class alluxio.conf.reference.DemoProperty
 
demote() - Method in class alluxio.master.service.jvmmonitor.JvmMonitorService
 
demote() - Method in class alluxio.master.service.NoopService
 
demote() - Method in class alluxio.master.service.rpc.RpcServerService
 
demote() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
demote() - Method in interface alluxio.master.service.SimpleService
Demotes the service back to NodeState.STANDBY state.
Deprecated - Annotation Type in alluxio.conf
An annotation for PropertyKeys that can be used to mark a key as deprecated (slated for removal).
DeprecatedKeyChecker - Class in alluxio.conf
This annotation checker should be used to determine whether a PropertyKey or PropertyKey.Template has a given annotation.
DeprecatedKeyChecker() - Constructor for class alluxio.conf.DeprecatedKeyChecker
Create a new instance of DeprecatedKeyChecker.
deRef() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
Decreases the reference count and return the current count.
DescendantType - Enum in alluxio.file.options
Type of descendant level processing for filesystem inodes.
DESCENDING_VALUE - Static variable in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
DESCENDING = 1;
description() - Static method in class alluxio.cli.fsadmin.command.DoctorCommand
 
description() - Static method in class alluxio.cli.fsadmin.command.JournalCommand
 
description() - Static method in class alluxio.cli.fsadmin.command.MetricsCommand
 
description() - Static method in class alluxio.cli.fsadmin.command.ReportCommand
 
description() - Static method in class alluxio.cli.fsadmin.journal.QuorumCommand
 
description() - Static method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
description() - Static method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
description() - Static method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
description() - Static method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
DESCRIPTION_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
DESCRIPTION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
deserialize(ReadableBuffer) - Method in class alluxio.grpc.DataMessageMarshaller
Deserialize data buffer to the message.
deserialize(ReadableBuffer) - Method in class alluxio.grpc.ReadResponseMarshaller
 
deserialize(ReadableBuffer) - Method in class alluxio.grpc.WriteRequestMarshaller
 
deserialize(byte[]) - Static method in class alluxio.job.util.SerializationUtils
Deserializes a byte array into an object.
deserialize(byte[], String) - Static method in class alluxio.job.util.SerializationUtils
Wrapper around #deserialize(Object) which throws a runtime exception with the given message on failure.
deserialize(InputStream) - Method in interface alluxio.master.journalv0.JournalFormatter
Returns a JournalInputStream from the given input stream.
deserialize(InputStream) - Method in class alluxio.master.journalv0.ProtoBufJournalFormatter
 
deserialize(byte[]) - Method in class alluxio.membership.DefaultServiceEntity
Deserialize the ServiceEntity from bytes.
deserialize(byte[]) - Method in class alluxio.membership.WorkerServiceEntity
 
deserialize(byte[]) - Static method in class alluxio.s3.TaggingData
Deserialize the XML (bytes).
deserialize(JsonParser, DeserializationContext) - Method in class alluxio.security.authorization.AccessControlList.AccessControlListDeserializer
Deserialize an AccessControlList object.
deserialize(JsonParser, DeserializationContext) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPointDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class alluxio.stress.worker.WorkerBenchDataPointDeserializer
 
deserializeContentType(Map<String, byte[]>) - Static method in class alluxio.proxy.s3.S3RestUtils
Given xAttr, parses and returns the Content-Type header metadata as its corresponding MediaType, or otherwise defaults to MediaType.APPLICATION_OCTET_STREAM_TYPE.
deserializeContentType(Map<String, byte[]>) - Static method in class alluxio.s3.NettyRestUtils
Given xAttr, parses and returns the Content-Type header metadata as its corresponding MediaType, or otherwise defaults to MediaType.APPLICATION_OCTET_STREAM_TYPE.
deserializeTaggingHeader(String, int) - Static method in class alluxio.proxy.s3.S3RestUtils
Given a URL-encoded Tagging header, parses and deserializes the Tagging metadata into a TaggingData object.
deserializeTags(Map<String, byte[]>) - Static method in class alluxio.proxy.s3.S3RestUtils
Given xAttr, parses and deserializes the Tagging metadata into a TaggingData object.
deserializeTags(Map<String, byte[]>) - Static method in class alluxio.s3.NettyRestUtils
Given xAttr, parses and deserializes the Tagging metadata into a TaggingData object.
destroy() - Static method in class alluxio.membership.AlluxioEtcdClient
Destroys the client and corresponding resources.
destroy() - Method in class alluxio.multi.process.MultiProcessCluster
Destroys the cluster.
destroy() - Method in class alluxio.web.HttpFilter
 
detachDatabase(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
detachDatabase(String) - Method in interface alluxio.client.table.TableMasterClient
Detaches an existing database in the catalog master.
detachDatabase(DetachDatabasePRequest, StreamObserver<DetachDatabasePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Detach existing database into the catalog, removing any metadata about the table
detachDatabase(DetachDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Detach existing database into the catalog, removing any metadata about the table
detachDatabase(DetachDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Detach existing database into the catalog, removing any metadata about the table
detachDatabase(DetachDatabasePRequest, StreamObserver<DetachDatabasePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Detach existing database into the catalog, removing any metadata about the table
DetachDatabasePRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DetachDatabasePRequest
DetachDatabasePRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DetachDatabasePRequest
DetachDatabasePRequestOrBuilder - Interface in alluxio.grpc.table
 
DetachDatabasePResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DetachDatabasePResponse
DetachDatabasePResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DetachDatabasePResponse
DetachDatabasePResponseOrBuilder - Interface in alluxio.grpc.table
 
dir(int) - Static method in interface alluxio.client.file.cache.CacheUsage.PartitionDescriptor
Creates a partition for a directory.
dir() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the directory index of the location.
DIR_HASH - Static variable in class alluxio.underfs.s3a.S3AUnderFileSystem
Static hash for a directory's empty contents.
DIRECT_BUFFER_POOL - Static variable in class alluxio.metrics.MetricsSystem
 
DIRECT_CHILDREN_LOADED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
DIRECT_CHILDREN_LOADED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
DIRECTCHILDRENLOADED_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
DirectedAcyclicGraph<T> - Class in alluxio.collections
A Directed Acyclic Graph (DAG).
DirectedAcyclicGraph() - Constructor for class alluxio.collections.DirectedAcyclicGraph
A Directed Acyclic Graph (DAG).
DirectedAcyclicGraphNode<T> - Class in alluxio.collections
A Directed Acyclic Graph (DAG) node.
DirectedAcyclicGraphNode(T, List<DirectedAcyclicGraphNode<T>>, List<DirectedAcyclicGraphNode<T>>) - Constructor for class alluxio.collections.DirectedAcyclicGraphNode
A Directed Acyclic Graph (DAG) node.
DirectedAcyclicGraphNode(T) - Constructor for class alluxio.collections.DirectedAcyclicGraphNode
A Directed Acyclic Graph (DAG) node.
DirectoryId - Class in alluxio.master.file.state
Class representing a directory ID.
DirectoryId() - Constructor for class alluxio.master.file.state.DirectoryId
Creates a new DirectoryId starting at (0, 0).
DirectoryId.UnmodifiableDirectoryId - Interface in alluxio.master.file.state
Immutable view of a DirectoryId.
DirectoryMarshaller - Interface in alluxio.util.compression
Interface for a directory marshaller to follow.
DirectoryMarshaller.Factory - Class in alluxio.util.compression
Factory to access the DirectoryMarshaller.
DirectoryMarshaller.Type - Enum in alluxio.util.compression
An enum to represent the different DirectoryMarshaller types.
DirectoryNotEmptyException - Exception in alluxio.exception
Exception for situations where an operation fails because a directory is not empty.
DirectoryNotEmptyException(String) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified detail message.
DirectoryNotEmptyException(String, Throwable) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified detail message and cause.
DirectoryNotEmptyException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified exception message and multiple parameters.
DirectoryNotEmptyException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
DirPartition(int) - Constructor for class alluxio.client.file.cache.CacheUsage.DirPartition
Creates a partition based on the directory's index.
DirView - Interface in alluxio.worker.block.meta
A view of StorageDir to provide more limited access.
DISABLEAREDESCENDANTSLOADEDCHECK_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
 
disableAuthentication() - Method in class alluxio.grpc.GrpcChannelBuilder
Disables authentication with the server.
disableAuthentication() - Method in class alluxio.grpc.GrpcService
If called, clients can access this service's methods without authentication.
disableAutoInboundFlowControl() - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
disableAutoRead(Channel) - Static method in class alluxio.util.network.NettyUtils
Disables auto read for a netty channel.
Disabled_VALUE - Static variable in enum alluxio.grpc.CommandType
Notify the worker that it has been disabled
disconnect() - Method in class alluxio.AbstractClient
 
disconnect() - Method in interface alluxio.Client
Closes the connection with the Alluxio remote and does the necessary cleanup.
dispose() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
DIST_CP_VALUE - Static variable in enum alluxio.grpc.OperationType
DIST_CP = 2;
DIST_LOAD_VALUE - Static variable in enum alluxio.grpc.OperationType
DIST_LOAD = 1;
DISTRIBUTED_FLAG - Static variable in class alluxio.stress.BaseParameters
 
DistributedCmdMetrics - Class in alluxio.master.job.metrics
DistributedCmdMetrics has definitions for distributed command metrics and help methods.
DistributedCmdMetrics() - Constructor for class alluxio.master.job.metrics.DistributedCmdMetrics
 
DistributedCommandUtil - Class in alluxio.cli.util
The util class for command operations.
doAuthentication() - Method in class alluxio.proxy.s3.S3Handler
Do S3 request authentication.
doAuthentication() - Method in class alluxio.worker.s3.S3NettyHandler
Do S3 request authentication.
DocGenerator - Class in alluxio.cli
Utility for generating docs.
DoctorCommand - Class in alluxio.cli.fsadmin.command
Shows errors or warnings that users should pay attention to.
DoctorCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.DoctorCommand
 
doFilter(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class alluxio.web.CORSFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class alluxio.web.HttpFilter
 
doFilter(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class alluxio.web.HttpFilter
Receives standard HTTP requests from the public doFilter method.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.JmxServlet
Process a GET request for the specified resource.
doGet(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.StacksServlet
 
Domain - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Domain
Domain.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Domain
Domain.ValueSetCase - Enum in alluxio.grpc.table
 
DOMAIN_FIELD_NUMBER - Static variable in class alluxio.grpc.GetQuorumInfoPResponse
 
DOMAIN_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
DOMAIN_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
DomainOrBuilder - Interface in alluxio.grpc.table
 
DOMAINSOCKETPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
 
donePartialListing() - Method in class alluxio.master.file.contexts.ListStatusContext
 
DORA_CLIENT_METADATA_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
DORA_CLIENT_METADATA_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_CLIENT_UFS_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
DORA_CLIENT_UFS_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_CLIENT_UFS_ROOT - Static variable in class alluxio.conf.PropertyKey
 
DORA_CLIENT_UFS_ROOT - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
DORA_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_UFS_LIST_STATUS_CACHE_NR_FILES - Static variable in class alluxio.conf.PropertyKey
 
DORA_UFS_LIST_STATUS_CACHE_NR_FILES - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_UFS_LIST_STATUS_CACHE_TTL - Static variable in class alluxio.conf.PropertyKey
 
DORA_UFS_LIST_STATUS_CACHE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_DIR - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_INDEX - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_TTL - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
DoraCacheClient - Class in alluxio.client.file.dora
Dora cache client.
DoraCacheClient(FileSystemContext) - Constructor for class alluxio.client.file.dora.DoraCacheClient
Constructor.
DoraCacheFileSystem - Class in alluxio.client.file
Dora Cache file system implementation.
DoraCacheFileSystem(FileSystem, FileSystemContext) - Constructor for class alluxio.client.file.DoraCacheFileSystem
Wraps a file system instance to forward messages.
DoraCacheFileSystem(FileSystem, FileSystemContext, DoraCacheClient) - Constructor for class alluxio.client.file.DoraCacheFileSystem
 
DoraCacheFileSystem.DoraCacheFileSystemFactory - Class in alluxio.client.file
DoraCacheFileSystem Factory.
DoraCacheFileSystemFactory() - Constructor for class alluxio.client.file.DoraCacheFileSystem.DoraCacheFileSystemFactory
Constructor.
DoraCachePositionReader - Class in alluxio.client.file.dora
Implementation of PositionReader that reads data through network from source.
DoraCachePositionReader(PositionReader, long, Optional<CloseableSupplier<PositionReader>>) - Constructor for class alluxio.client.file.dora.DoraCachePositionReader
 
DoraFileOutStream - Class in alluxio.client.file
Provides a streaming API to write a file.
DoraFileOutStream(DoraCacheClient, NettyDataWriter, AlluxioURI, OutStreamOptions, FileSystemContext, FileOutStream, String) - Constructor for class alluxio.client.file.DoraFileOutStream
Creates a new file output stream.
DoraLoadJob - Class in alluxio.master.job
Load job that loads a file or a directory into Alluxio.
DoraLoadJob(String, Optional<String>, String, OptionalLong, boolean, boolean, boolean, boolean) - Constructor for class alluxio.master.job.DoraLoadJob
Constructor.
DoraLoadJob.DoraLoadTask - Class in alluxio.master.job
Dora load task.
DoraLoadTask() - Constructor for class alluxio.master.job.DoraLoadJob.DoraLoadTask
Constructor.
DoraLoadTask(List<UfsStatus>) - Constructor for class alluxio.master.job.DoraLoadJob.DoraLoadTask
Constructor.
DoraMeta - Class in alluxio.proto.meta
 
DoraMeta.FileStatus - Class in alluxio.proto.meta
Metadata used in Dora Worker.
DoraMeta.FileStatus.Builder - Class in alluxio.proto.meta
Metadata used in Dora Worker.
DoraMeta.FileStatusOrBuilder - Interface in alluxio.proto.meta
 
DoraMetaBench - Class in alluxio.dora.meta
This benchmark measures the time it takes to read/write metadata from the dora worker metastore The following parameters can be varied: mFileCount - the number of file meta created mUseZipf - if true depths and inodes to be read will be chosen according to a Zipfian distribution.
DoraMetaBench() - Constructor for class alluxio.dora.meta.DoraMetaBench
 
DoraMetaBench.Db - Class in alluxio.dora.meta
 
DoraMetaBench.ThreadState - Class in alluxio.dora.meta
 
DoraMetaManager - Class in alluxio.worker.dora
The Dora metadata manager that orchestrates the metadata operations.
DoraMetaManager(AlluxioConfiguration, PagedDoraWorker, CacheManager, DoraUfsManager) - Constructor for class alluxio.worker.dora.DoraMetaManager
Creates a dora meta manager.
DoraMetaStore - Interface in alluxio.worker.dora
The Dora metadata Store.
DoraOpenFileHandleContainer - Class in alluxio.worker.dora
A collection of open file handles in a dora worker.
DoraOutStream - Class in alluxio.client.file.ufs
A Dora output stream.
DoraOutStream(AlluxioURI, OutStreamOptions, FileSystemContext, String, DoraCacheClient) - Constructor for class alluxio.client.file.ufs.DoraOutStream
Creates a new file output stream.
DoraTestTodoItem - Annotation Type in alluxio.annotation.dora
An annotation that helps identify test code and test cases that need to be removed or fixed during transitioning the code base to the new Dora architecture.
DoraTestTodoItem.Action - Enum in alluxio.annotation.dora
The action that owner should take on the item.
DoraUfsManager - Class in alluxio.worker.dora
Dora UFS manager.
DoraUfsManager() - Constructor for class alluxio.worker.dora.DoraUfsManager
 
DoraWorker - Interface in alluxio.worker.dora
A block worker in the Alluxio system.
DoraWorkerClientServiceHandler - Class in alluxio.worker.grpc
Server side implementation of the gRPC dora worker interface.
DoraWorkerClientServiceHandler(DoraWorker) - Constructor for class alluxio.worker.grpc.DoraWorkerClientServiceHandler
Creates a new implementation of gRPC BlockWorker interface.
DoraWorkerModule - Class in alluxio.worker.modules
Guice module for block worker.
DoraWorkerModule() - Constructor for class alluxio.worker.modules.DoraWorkerModule
 
doTrace(HttpServletRequest, HttpServletResponse) - Method in class alluxio.web.JmxServlet
Disable TRACE method to avoid TRACE vulnerability.
DOUBLE_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
DOUBLE_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Value
 
doubleBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
DoubleColumnStatsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DoubleColumnStatsData
DoubleColumnStatsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.DoubleColumnStatsData
DoubleColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
 
DOUBLEVALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricValue
 
downgrade() - Method in class alluxio.resource.RWLockResource
Downgrade from a write to a read lock.
downgradeLastEdge() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
downgradeLastEdge() - Method in interface alluxio.master.file.meta.InodeLockList
Downgrades the last edge lock in the lock list from WRITE lock to READ lock.
downgradeLastEdge() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
downgradeToRead() - Method in class alluxio.master.file.meta.LockedInodePath
Downgrades all locks in this list to read locks.
downgradeToReadLocks() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
downgradeToReadLocks() - Method in interface alluxio.master.file.meta.InodeLockList
Downgrades all locks in the current lock list to read locks.
downgradeToReadLocks() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
DOWNLOAD_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
downloadFile(String) - Method in class alluxio.proxy.PathsRestServiceHandler
 
downloadSnapshot(StreamObserver<DownloadSnapshotPResponse>) - Method in interface alluxio.grpc.RaftJournalServiceGrpc.AsyncService
Deprecated.
downloadSnapshot(StreamObserver<DownloadSnapshotPResponse>) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceStub
Deprecated.
downloadSnapshotFromOtherMasters() - Method in class alluxio.master.journal.raft.RaftSnapshotManager
Launches an asynchronous download of the most updated snapshot found on other masters in the cluster.
DownloadSnapshotPRequest - Class in alluxio.grpc
Deprecated.
DownloadSnapshotPRequest.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.DownloadSnapshotPRequest
DownloadSnapshotPRequestOrBuilder - Interface in alluxio.grpc
Deprecated.
DownloadSnapshotPResponse - Class in alluxio.grpc
Deprecated.
DownloadSnapshotPResponse.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.DownloadSnapshotPResponse
DownloadSnapshotPResponseOrBuilder - Interface in alluxio.grpc
Deprecated.
drain() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Removes all available unexecuted submitted and forked tasks from scheduling queues and adds them to the given collection, without altering their execution status.
drainTo(Collection<? super T>) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
drainTo(Collection<? super T>, int) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
DropAllCommand - Class in alluxio.cli.command.metadatacache
The metadata cache 'dropAll' subcommand.
DropAllCommand(FileSystem, AlluxioConfiguration, String) - Constructor for class alluxio.cli.command.metadatacache.DropAllCommand
 
DropCommand - Class in alluxio.cli.command.metadatacache
The metadata cache 'drop' subcommand.
DropCommand(FileSystem, AlluxioConfiguration, String) - Constructor for class alluxio.cli.command.metadatacache.DropCommand
 
dropMetadataCache(AlluxioURI) - Method in class alluxio.client.file.MetadataCachingFileSystem
Best efforts to drops metadata cache of a given uri, all its ancestors and descendants.
dropMetadataCacheAll() - Method in class alluxio.client.file.MetadataCachingFileSystem
Drop all metadata cache.
dropReference() - Method in class alluxio.concurrent.ClientRWLock
Decrements the reference count.
DST_FIELD_NUMBER - Static variable in class alluxio.grpc.Route
 
DST_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
DST_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
DST_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
DSTPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPOptions
 
DSTPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePRequest
 
DUMMY - Static variable in class alluxio.wire.WorkerNetAddress
 
DUMMY_BLOCK_ID - Static variable in class alluxio.client.file.dora.DoraCacheClient
 
DUMMY_BLOCK_SIZE - Static variable in class alluxio.worker.dora.PagedDoraWorker
 
DUMMY_MOUNT_ID - Static variable in class alluxio.client.file.DoraCacheFileSystem
 
dumpInfo() - Method in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
Get info of buckets in the encoder.
dumpInformationOnExit() - Static method in class alluxio.ProcessUtils
Outputs process critical information like metrics and jstack before it exits.
dumpInformationOnFailover(ExecutorService) - Static method in class alluxio.ProcessUtils
Outputs process critical information like metrics and jstack before the primary master fails over to standby.
dumpJournal() - Method in class alluxio.master.journal.tool.UfsJournalDumper
 
dumpMainInfo() - Method in class alluxio.wire.WorkerNetAddress
dump the main info of the WorkerNetAddress object.
dumpStats() - Method in class alluxio.scheduler.job.Task.TaskStat
 
DURATION_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
durationBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
DynamicResourcePool<T> - Class in alluxio.resource
A dynamic pool that manages the resources.
DynamicResourcePool(DynamicResourcePool.Options) - Constructor for class alluxio.resource.DynamicResourcePool
Creates a dynamic pool instance.
DynamicResourcePool.Options - Class in alluxio.resource
Options to initialize a Dynamic resource pool.
DynamicResourcePool.ResourceInternal<R> - Class in alluxio.resource
A wrapper on the resource to include the last time at which it was used.
DynamicResourcePool.SelectionPolicy - Enum in alluxio.resource
A policy specifying in what order to pick a resource item from a pool.

E

E2BIG() - Static method in class alluxio.jnifuse.ErrorCodes
Argument list too long
EACCES() - Static method in class alluxio.jnifuse.ErrorCodes
Permission denied
EADDRINUSE() - Static method in class alluxio.jnifuse.ErrorCodes
Address already in use
EADDRNOTAVAIL() - Static method in class alluxio.jnifuse.ErrorCodes
Cannot assign requested address
EADV() - Static method in class alluxio.jnifuse.ErrorCodes
Advertise error
EAFNOSUPPORT() - Static method in class alluxio.jnifuse.ErrorCodes
Address family not supported by protocol
EAGAIN() - Static method in class alluxio.jnifuse.ErrorCodes
Try again
EALREADY() - Static method in class alluxio.jnifuse.ErrorCodes
Operation already in progress
EBADE() - Static method in class alluxio.jnifuse.ErrorCodes
Invalid exchange
EBADF() - Static method in class alluxio.jnifuse.ErrorCodes
Bad file number
EBADFD() - Static method in class alluxio.jnifuse.ErrorCodes
File descriptor in bad state
EBADMSG() - Static method in class alluxio.jnifuse.ErrorCodes
Not a data message
EBADR() - Static method in class alluxio.jnifuse.ErrorCodes
Invalid request descriptor
EBADRQC() - Static method in class alluxio.jnifuse.ErrorCodes
Invalid request code
EBADSLT() - Static method in class alluxio.jnifuse.ErrorCodes
Invalid slot
EBFONT() - Static method in class alluxio.jnifuse.ErrorCodes
Bad font file format
EBUSY() - Static method in class alluxio.jnifuse.ErrorCodes
Device or resource busy
ECANCELED() - Static method in class alluxio.jnifuse.ErrorCodes
Operation Canceled
ECHILD() - Static method in class alluxio.jnifuse.ErrorCodes
No child processes
ECHRNG() - Static method in class alluxio.jnifuse.ErrorCodes
Channel number out of range
ECOMM() - Static method in class alluxio.jnifuse.ErrorCodes
Communication error on send
ECONNABORTED() - Static method in class alluxio.jnifuse.ErrorCodes
Software caused connection abort
ECONNREFUSED() - Static method in class alluxio.jnifuse.ErrorCodes
Connection refused
ECONNRESET() - Static method in class alluxio.jnifuse.ErrorCodes
Connection reset by peer
EDEADLK() - Static method in class alluxio.jnifuse.ErrorCodes
Resource deadlock would occur
EDEADLOCK() - Static method in class alluxio.jnifuse.ErrorCodes
 
EDESTADDRREQ() - Static method in class alluxio.jnifuse.ErrorCodes
Destination address required
Edge - Class in alluxio.master.file.meta
An edge in the inode tree.
Edge(long, String) - Constructor for class alluxio.master.file.meta.Edge
 
EdgeEntry - Class in alluxio.master.file.meta
Representation for an edge and the inode it points to.
EdgeEntry(long, String, long) - Constructor for class alluxio.master.file.meta.EdgeEntry
 
EDOM() - Static method in class alluxio.jnifuse.ErrorCodes
Math argument out of domain of func
EDOTDOT() - Static method in class alluxio.jnifuse.ErrorCodes
RFS specific error
EDQUOT() - Static method in class alluxio.jnifuse.ErrorCodes
Quota exceeded
EEXIST() - Static method in class alluxio.jnifuse.ErrorCodes
File exists
EFAULT() - Static method in class alluxio.jnifuse.ErrorCodes
Bad address
EFBIG() - Static method in class alluxio.jnifuse.ErrorCodes
File too large
EHOSTDOWN() - Static method in class alluxio.jnifuse.ErrorCodes
Host is down
EHOSTUNREACH() - Static method in class alluxio.jnifuse.ErrorCodes
No route to host
EIDRM() - Static method in class alluxio.jnifuse.ErrorCodes
Identifier removed
EILSEQ() - Static method in class alluxio.jnifuse.ErrorCodes
Illegal byte sequence
EINPROGRESS() - Static method in class alluxio.jnifuse.ErrorCodes
Operation now in progress
EINTR() - Static method in class alluxio.jnifuse.ErrorCodes
Interrupted system call
EINVAL() - Static method in class alluxio.jnifuse.ErrorCodes
Invalid argument
EIO() - Static method in class alluxio.jnifuse.ErrorCodes
I/O error
EISCONN() - Static method in class alluxio.jnifuse.ErrorCodes
Transport endpoint is already connected
EISDIR() - Static method in class alluxio.jnifuse.ErrorCodes
Is a directory
EISNAM() - Static method in class alluxio.jnifuse.ErrorCodes
Is a named type file
EKEYEXPIRED() - Static method in class alluxio.jnifuse.ErrorCodes
Key has expired
EKEYREJECTED() - Static method in class alluxio.jnifuse.ErrorCodes
Key was rejected by service
EKEYREVOKED() - Static method in class alluxio.jnifuse.ErrorCodes
Key has been revoked
EL2HLT() - Static method in class alluxio.jnifuse.ErrorCodes
Level 2 halted
EL2NSYNC() - Static method in class alluxio.jnifuse.ErrorCodes
Level 2 not synchronized
EL3HLT() - Static method in class alluxio.jnifuse.ErrorCodes
Level 3 halted
EL3RST() - Static method in class alluxio.jnifuse.ErrorCodes
Level 3 reset
ElapsedTimeClock - Class in alluxio.clock
A monotonically increasing clock for calculating elapsed time.
ElapsedTimeClock() - Constructor for class alluxio.clock.ElapsedTimeClock
 
ELIBACC() - Static method in class alluxio.jnifuse.ErrorCodes
Can not access a needed shared library
ELIBBAD() - Static method in class alluxio.jnifuse.ErrorCodes
Accessing a corrupted shared library
ELIBEXEC() - Static method in class alluxio.jnifuse.ErrorCodes
Cannot exec a shared library directly
ELIBMAX() - Static method in class alluxio.jnifuse.ErrorCodes
Attempting to link in too many shared libraries
ELIBSCN() - Static method in class alluxio.jnifuse.ErrorCodes
.lib section in a.out corrupted
ELNRNG() - Static method in class alluxio.jnifuse.ErrorCodes
Link number out of range
ELOOP() - Static method in class alluxio.jnifuse.ErrorCodes
Too many symbolic links encountered
EMBEDDED_JOURNAL_ALREADY_TRANSFERRING - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_FAILOVER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_FAILOVER_METADATA_SYNC - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_GROW - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_NEW_MEMBER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_OUTSIDE_CLUSTER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_REPEAT_TRANSFER_LEADER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_REPLACE_ALL - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_RESIZE - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_RESTART - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_RESTART_STRESS - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_SNAPSHOT_FOLLOWER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_SNAPSHOT_MASTER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_SNAPSHOT_SINGLE_MASTER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_SNAPSHOT_TRANSFER_LOAD - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_TRANSFER_LEADER - Static variable in class alluxio.multi.process.PortCoordination
 
EMBEDDED_JOURNAL_UNAVAILABLE_MASTER - Static variable in class alluxio.multi.process.PortCoordination
 
EmbeddedLogicalAuthority - Class in alluxio.uri
A logical host authority implementation.
EmbeddedLogicalAuthority(String) - Constructor for class alluxio.uri.EmbeddedLogicalAuthority
 
EMEDIUMTYPE() - Static method in class alluxio.jnifuse.ErrorCodes
Wrong medium type
EMFILE() - Static method in class alluxio.jnifuse.ErrorCodes
Too many open files
EMLINK() - Static method in class alluxio.jnifuse.ErrorCodes
Too many links
EMPTY - Static variable in class alluxio.s3.S3Constants
 
EMPTY_ACL - Static variable in class alluxio.security.authorization.AccessControlList
 
EMPTY_ACL - Static variable in class alluxio.underfs.BaseUnderFileSystem
 
EMPTY_CREATION_TIME - Static variable in class alluxio.util.webui.UIFileInfo.LocalFileInfo
The constant EMPTY_CREATION_TIME.
EMPTY_DEFAULT_ACL - Static variable in class alluxio.security.authorization.DefaultAccessControlList
 
EMPTY_URI - Static variable in class alluxio.AlluxioURI
 
emptyConfig() - Static method in class alluxio.underfs.UnderFileSystemConfiguration
 
EMSGSIZE() - Static method in class alluxio.jnifuse.ErrorCodes
Message too long
EMULTIHOP() - Static method in class alluxio.jnifuse.ErrorCodes
Multihop attempted
enableAutoRead(Channel) - Static method in class alluxio.util.network.NettyUtils
Enables auto read for a netty channel.
EnableWorkerCommand - Class in alluxio.cli.fsadmin.command
The DecommissionWorkerCommand can specify to disable certain workers in the cluster, so they are not allowed to register again.
EnableWorkerCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.EnableWorkerCommand
 
ENAMETOOLONG() - Static method in class alluxio.jnifuse.ErrorCodes
File name too long
ENAVAIL() - Static method in class alluxio.jnifuse.ErrorCodes
No XENIX semaphores available
encode(CacheScope) - Method in class alluxio.client.file.cache.cuckoofilter.ScopeEncoder
Encode scope information into integer.
encode(int) - Method in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
Encode the size into a group.
encode(T) - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
Encode a single object into a byte string.
encode(ByteBuf) - Method in interface alluxio.network.protocol.EncodedMessage
Encodes the message to the output ByteBuf.
encode(ByteBuf) - Method in enum alluxio.network.protocol.RPCMessage.Type
 
encode(ChannelHandlerContext, RPCMessage, List<Object>) - Method in class alluxio.network.protocol.RPCMessageEncoder
 
encode(ByteBuf) - Method in class alluxio.network.protocol.RPCProtoMessage
 
EncodedMessage - Interface in alluxio.network.protocol
Represents an encoded message.
encodeResponseTimeNsRaw(Histogram) - Method in class alluxio.stress.common.TaskResultStatistics
Encodes the histogram into the internal byte array.
encodeToken(String) - Static method in class alluxio.s3.ListBucketResult
Generate a continuation token which is used in get Bucket.
ENCRYPTION_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
ENCRYPTION_MASTER_CLIENT_SERVICE = 1003;
END_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
END_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
END_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
endsInInode() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
endsInInode() - Method in interface alluxio.master.file.meta.InodeLockList
 
endsInInode() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
ENETDOWN() - Static method in class alluxio.jnifuse.ErrorCodes
Network is down
ENETRESET() - Static method in class alluxio.jnifuse.ErrorCodes
Network dropped connection because of reset
ENETUNREACH() - Static method in class alluxio.jnifuse.ErrorCodes
Network is unreachable
ENFILE() - Static method in class alluxio.jnifuse.ErrorCodes
File table overflow
ENOANO() - Static method in class alluxio.jnifuse.ErrorCodes
No anode
ENOATTR() - Static method in class alluxio.jnifuse.ErrorCodes
The extended attribute does not exist
ENOBUFS() - Static method in class alluxio.jnifuse.ErrorCodes
No buffer space available
ENOCSI() - Static method in class alluxio.jnifuse.ErrorCodes
No CSI structure available
ENODATA() - Static method in class alluxio.jnifuse.ErrorCodes
No data available
ENODEV() - Static method in class alluxio.jnifuse.ErrorCodes
No such device
ENOENT() - Static method in class alluxio.jnifuse.ErrorCodes
No such file or directory
ENOEXEC() - Static method in class alluxio.jnifuse.ErrorCodes
Exec format error
ENOKEY() - Static method in class alluxio.jnifuse.ErrorCodes
Required key not available
ENOLCK() - Static method in class alluxio.jnifuse.ErrorCodes
No record locks available
ENOLINK() - Static method in class alluxio.jnifuse.ErrorCodes
Link has been severed
ENOMEDIUM() - Static method in class alluxio.jnifuse.ErrorCodes
No medium found
ENOMEM() - Static method in class alluxio.jnifuse.ErrorCodes
Out of memory
ENOMSG() - Static method in class alluxio.jnifuse.ErrorCodes
No message of desired type
ENONET() - Static method in class alluxio.jnifuse.ErrorCodes
Machine is not on the network
ENOPKG() - Static method in class alluxio.jnifuse.ErrorCodes
Package not installed
ENOPROTOOPT() - Static method in class alluxio.jnifuse.ErrorCodes
Protocol not available
ENOSPC() - Static method in class alluxio.jnifuse.ErrorCodes
No space left on device
ENOSR() - Static method in class alluxio.jnifuse.ErrorCodes
Out of streams resources
ENOSTR() - Static method in class alluxio.jnifuse.ErrorCodes
Device not a stream
ENOSYS() - Static method in class alluxio.jnifuse.ErrorCodes
Function not implemented
ENOTBLK() - Static method in class alluxio.jnifuse.ErrorCodes
Block device required
ENOTCONN() - Static method in class alluxio.jnifuse.ErrorCodes
Transport endpoint is not connected
ENOTDIR() - Static method in class alluxio.jnifuse.ErrorCodes
Not a directory
ENOTEMPTY() - Static method in class alluxio.jnifuse.ErrorCodes
Directory not empty
ENOTNAM() - Static method in class alluxio.jnifuse.ErrorCodes
Not a XENIX named type file
ENOTRECOVERABLE() - Static method in class alluxio.jnifuse.ErrorCodes
State not recoverable
ENOTSOCK() - Static method in class alluxio.jnifuse.ErrorCodes
Socket operation on non-socket
ENOTSUP() - Static method in class alluxio.jnifuse.ErrorCodes
The file system does not support extended attributes or has the feature disabled
ENOTTY() - Static method in class alluxio.jnifuse.ErrorCodes
Not a typewriter
ENOTUNIQ() - Static method in class alluxio.jnifuse.ErrorCodes
Name not unique on network
enqueueTaskForWorker(WorkerInfo, Task) - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoHub
Enqueue task for worker.
ensureFullInodePath(LockedInodePath) - Method in class alluxio.master.file.meta.InodeTree
Attempts to extend an existing LockedInodePath to reach the target inode (the last inode for the full path).
ensureFullPathAndUpdateCache(LockedInodePath) - Method in class alluxio.master.file.DefaultFileSystemMaster
Checks to see if the entire path exists in Alluxio.
ENTITY_TOO_SMALL - Static variable in class alluxio.s3.S3ErrorCode
 
ENTITY_TOO_SMALL - Static variable in class alluxio.s3.S3ErrorCode.Name
 
ENTRIES_FIELD_NUMBER - Static variable in class alluxio.grpc.PAcl
 
ENTRIES_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPRequest
 
ENTRIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAclEntry
 
Entry(CheckpointName, CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader.Entry
 
ENTRYCOUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPStatus
 
EntryOutputStream(UnderFileSystem, URI, JournalFormatter, UfsJournalWriter) - Constructor for class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
 
entrySet() - Method in class alluxio.collections.ConcurrentIdentityHashMap
Returns a set representing the entries of this map at the time of calling.
entrySet() - Method in class alluxio.conf.AlluxioProperties
 
enumBuilder(String, Class<? extends Enum>) - Static method in class alluxio.conf.PropertyKey.Builder
 
Environment - Class in alluxio.jnifuse.utils
This file mostly derived from rocksdb lib.
Environment() - Constructor for class alluxio.jnifuse.utils.Environment
 
EnvironmentUtils - Class in alluxio.util
Utilities to detect environment Alluxio is running in.
ENXIO() - Static method in class alluxio.jnifuse.ErrorCodes
No such device or address
EOF_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
 
EOF_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
EofResponseEvent - Class in alluxio.client.file.dora.netty.event
Eof response event.
EofResponseEvent() - Constructor for class alluxio.client.file.dora.netty.event.EofResponseEvent
 
EOPNOTSUPP() - Static method in class alluxio.jnifuse.ErrorCodes
Operation not supported on transport endpoint
EOVERFLOW() - Static method in class alluxio.jnifuse.ErrorCodes
Value too large for defined data type
EOWNERDEAD() - Static method in class alluxio.jnifuse.ErrorCodes
Owner died
EPERM() - Static method in class alluxio.jnifuse.ErrorCodes
Operation not permitted
EPFNOSUPPORT() - Static method in class alluxio.jnifuse.ErrorCodes
Protocol family not supported
EPIPE() - Static method in class alluxio.jnifuse.ErrorCodes
Broken pipe
EPROTO() - Static method in class alluxio.jnifuse.ErrorCodes
Protocol error
EPROTONOSUPPORT() - Static method in class alluxio.jnifuse.ErrorCodes
Protocol not supported
EPROTOTYPE() - Static method in class alluxio.jnifuse.ErrorCodes
Protocol wrong type for socket
equalConstantByteArray(byte, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with a constant sequence of bytes of the given value and length.
equalIncreasingByteArray(int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with an increasing sequence of bytes of the given length, starting from 0.
equalIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with an increasing sequence of bytes of the given length, starting from the given value.
equalIncreasingByteBuf(int, int, ByteBuf) - Static method in class alluxio.util.io.BufferUtils
Checks if the given ByteBuf starts with an increasing sequence of bytes starting at the given value of length equal to or greater than the given length.
equalIncreasingByteBuffer(int, int, ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Checks if the given ByteBuffer starts with an increasing sequence of bytes starting at the given value of length equal to or greater than the given length.
equals(Object) - Method in class alluxio.AlluxioURI
 
equals(Object) - Method in class alluxio.cli.docgen.MetricsDocGenerator.FileWriterKey
 
equals(Object) - Method in class alluxio.cli.fs.command.FileLocation
 
equals(Object) - Method in class alluxio.cli.LogLevel.TargetInfo
 
equals(Object) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
equals(Object) - Method in class alluxio.client.file.cache.CacheUsage.DirPartition
 
equals(Object) - Method in class alluxio.client.file.cache.CacheUsage.FilePartition
 
equals(Object) - Method in class alluxio.client.file.cache.CacheUsage.ScopePartition
 
equals(Object) - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
equals(Object) - Method in class alluxio.client.file.cache.PageId
 
equals(Object) - Method in class alluxio.client.file.cache.PageInfo
 
equals(Object) - Method in class alluxio.client.file.CacheContext
 
equals(Object) - Method in class alluxio.client.file.FileSystemCache.Key
 
equals(Object) - Method in class alluxio.client.file.FileSystemContext.ClientPoolKey
 
equals(Object) - Method in class alluxio.client.file.options.InStreamOptions
 
equals(Object) - Method in class alluxio.client.file.options.OutStreamOptions
 
equals(Object) - Method in class alluxio.client.file.URIStatus
 
equals(Object) - Method in class alluxio.client.hive.HiveCacheContext
 
equals(Object) - Method in class alluxio.client.quota.CacheQuota
 
equals(Object) - Method in class alluxio.client.quota.CacheScope
 
equals(Object) - Method in class alluxio.collections.DelegatingSet
 
equals(Object) - Method in class alluxio.collections.Pair
 
equals(Object) - Method in class alluxio.collections.TwoKeyConcurrentMap
The equals implementation for this map simply uses the superclass's equals.
equals(Object) - Method in class alluxio.conf.PropertyKey
 
equals(Object) - Method in class alluxio.conf.Source
 
equals(Object) - Method in class alluxio.fuse.options.FuseCliOptions
 
equals(Object) - Method in class alluxio.fuse.options.MountCliOptions
 
equals(Object) - Method in class alluxio.fuse.options.MountOptions
 
equals(Object) - Method in class alluxio.grpc.ActionInfo
 
equals(Object) - Method in class alluxio.grpc.AddPolicyPOptions
 
equals(Object) - Method in class alluxio.grpc.AddPolicyPRequest
 
equals(Object) - Method in class alluxio.grpc.AddPolicyPResponse
 
equals(Object) - Method in class alluxio.grpc.AddQuorumServerRequest
 
equals(Object) - Method in class alluxio.grpc.AsyncCacheRequest
 
equals(Object) - Method in class alluxio.grpc.AsyncCacheResponse
 
equals(Object) - Method in class alluxio.grpc.BackupPOptions
 
equals(Object) - Method in class alluxio.grpc.BackupPRequest
 
equals(Object) - Method in class alluxio.grpc.BackupPStatus
 
equals(Object) - Method in class alluxio.grpc.BackupStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.Block
 
equals(Object) - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
equals(Object) - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
equals(Object) - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
equals(Object) - Method in class alluxio.grpc.BlockIdList
 
equals(Object) - Method in class alluxio.grpc.BlockInfo
 
equals(Object) - Method in class alluxio.grpc.BlockLocation
 
equals(Object) - Method in class alluxio.grpc.BlockMasterInfo
 
equals(Object) - Method in class alluxio.grpc.BlockStatus
 
equals(Object) - Method in class alluxio.grpc.BlockStoreLocationProto
 
equals(Object) - Method in class alluxio.grpc.BuildVersion
 
equals(Object) - Method in class alluxio.grpc.CacheRequest
 
equals(Object) - Method in class alluxio.grpc.CacheResponse
 
equals(Object) - Method in class alluxio.grpc.CancelPOptions
 
equals(Object) - Method in class alluxio.grpc.CancelPRequest
 
equals(Object) - Method in class alluxio.grpc.CancelPResponse
 
equals(Object) - Method in class alluxio.grpc.CancelTaskCommand
 
equals(Object) - Method in class alluxio.grpc.CheckAccessPOptions
 
equals(Object) - Method in class alluxio.grpc.CheckAccessPRequest
 
equals(Object) - Method in class alluxio.grpc.CheckAccessPResponse
 
equals(Object) - Method in class alluxio.grpc.CheckConsistencyPOptions
 
equals(Object) - Method in class alluxio.grpc.CheckConsistencyPRequest
 
equals(Object) - Method in class alluxio.grpc.CheckConsistencyPResponse
 
equals(Object) - Method in class alluxio.grpc.CheckpointPOptions
 
equals(Object) - Method in class alluxio.grpc.CheckpointPResponse
 
equals(Object) - Method in class alluxio.grpc.CheckRequest
 
equals(Object) - Method in class alluxio.grpc.CheckResponse
 
equals(Object) - Method in class alluxio.grpc.Chunk
 
equals(Object) - Method in class alluxio.grpc.ClearMetricsPRequest
 
equals(Object) - Method in class alluxio.grpc.ClearMetricsPResponse
 
equals(Object) - Method in class alluxio.grpc.ClearMetricsRequest
 
equals(Object) - Method in class alluxio.grpc.ClearMetricsResponse
 
equals(Object) - Method in class alluxio.grpc.ClientMetrics
 
equals(Object) - Method in class alluxio.grpc.CmdProgress
 
equals(Object) - Method in class alluxio.grpc.CmdStatusBlock
 
equals(Object) - Method in class alluxio.grpc.CmdSummary
 
equals(Object) - Method in class alluxio.grpc.Command
 
equals(Object) - Method in class alluxio.grpc.CommitBlockPOptions
 
equals(Object) - Method in class alluxio.grpc.CommitBlockPRequest
 
equals(Object) - Method in class alluxio.grpc.CommitBlockPResponse
 
equals(Object) - Method in class alluxio.grpc.CompleteFilePOptions
 
equals(Object) - Method in class alluxio.grpc.CompleteFilePRequest
 
equals(Object) - Method in class alluxio.grpc.CompleteFilePResponse
 
equals(Object) - Method in class alluxio.grpc.ConfigCheckReport
 
equals(Object) - Method in class alluxio.grpc.ConfigProperties
 
equals(Object) - Method in class alluxio.grpc.ConfigProperty
 
equals(Object) - Method in class alluxio.grpc.CopyJobPOptions
 
equals(Object) - Method in class alluxio.grpc.CopyRequest
 
equals(Object) - Method in class alluxio.grpc.CopyResponse
 
equals(Object) - Method in class alluxio.grpc.CreateDirectoryPOptions
 
equals(Object) - Method in class alluxio.grpc.CreateDirectoryPRequest
 
equals(Object) - Method in class alluxio.grpc.CreateDirectoryPResponse
 
equals(Object) - Method in class alluxio.grpc.CreateFilePOptions
 
equals(Object) - Method in class alluxio.grpc.CreateFilePRequest
 
equals(Object) - Method in class alluxio.grpc.CreateFilePResponse
 
equals(Object) - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
equals(Object) - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
equals(Object) - Method in class alluxio.grpc.DeletePOptions
 
equals(Object) - Method in class alluxio.grpc.DeletePRequest
 
equals(Object) - Method in class alluxio.grpc.DeletePResponse
 
equals(Object) - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.ErrorInfo
 
equals(Object) - Method in class alluxio.grpc.ExistsPOptions
 
equals(Object) - Method in class alluxio.grpc.ExistsPRequest
 
equals(Object) - Method in class alluxio.grpc.ExistsPResponse
 
equals(Object) - Method in class alluxio.grpc.File
 
equals(Object) - Method in class alluxio.grpc.FileBlockInfo
 
equals(Object) - Method in class alluxio.grpc.FileFailure
 
equals(Object) - Method in class alluxio.grpc.FileInfo
 
equals(Object) - Method in class alluxio.grpc.FileSystemCommand
 
equals(Object) - Method in class alluxio.grpc.FileSystemCommandOptions
 
equals(Object) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
equals(Object) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
equals(Object) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
equals(Object) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
equals(Object) - Method in class alluxio.grpc.FreePOptions
 
equals(Object) - Method in class alluxio.grpc.FreePRequest
 
equals(Object) - Method in class alluxio.grpc.FreePResponse
 
equals(Object) - Method in class alluxio.grpc.FreeWorkerRequest
 
equals(Object) - Method in class alluxio.grpc.FreeWorkerResponse
 
equals(Object) - Method in class alluxio.grpc.FsOpPId
 
equals(Object) - Method in class alluxio.grpc.GetActionInfoOptions
 
equals(Object) - Method in class alluxio.grpc.GetActionInfoRequest
 
equals(Object) - Method in class alluxio.grpc.GetActionInfoResponse
 
equals(Object) - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
equals(Object) - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
equals(Object) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
equals(Object) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
equals(Object) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
equals(Object) - Method in class alluxio.grpc.GetBlockInfoPOptions
 
equals(Object) - Method in class alluxio.grpc.GetBlockInfoPRequest
 
equals(Object) - Method in class alluxio.grpc.GetBlockInfoPResponse
 
equals(Object) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
equals(Object) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
equals(Object) - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
equals(Object) - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
equals(Object) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
equals(Object) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
equals(Object) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
equals(Object) - Method in class alluxio.grpc.GetCmdStatusOptions
 
equals(Object) - Method in class alluxio.grpc.GetCmdStatusRequest
 
equals(Object) - Method in class alluxio.grpc.GetCmdStatusResponse
 
equals(Object) - Method in class alluxio.grpc.GetConfigHashPOptions
 
equals(Object) - Method in class alluxio.grpc.GetConfigHashPResponse
 
equals(Object) - Method in class alluxio.grpc.GetConfigReportPOptions
 
equals(Object) - Method in class alluxio.grpc.GetConfigReportPResponse
 
equals(Object) - Method in class alluxio.grpc.GetConfigurationPOptions
 
equals(Object) - Method in class alluxio.grpc.GetConfigurationPResponse
 
equals(Object) - Method in class alluxio.grpc.GetFileInfoPOptions
 
equals(Object) - Method in class alluxio.grpc.GetFileInfoPRequest
 
equals(Object) - Method in class alluxio.grpc.GetFileInfoPResponse
 
equals(Object) - Method in class alluxio.grpc.GetFilePathPRequest
 
equals(Object) - Method in class alluxio.grpc.GetFilePathPResponse
 
equals(Object) - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
equals(Object) - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
equals(Object) - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
equals(Object) - Method in class alluxio.grpc.GetJobProgressPRequest
 
equals(Object) - Method in class alluxio.grpc.GetJobProgressPResponse
 
equals(Object) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
equals(Object) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
equals(Object) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
equals(Object) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
equals(Object) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
equals(Object) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
equals(Object) - Method in class alluxio.grpc.GetJobStatusPOptions
 
equals(Object) - Method in class alluxio.grpc.GetJobStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.GetJobStatusPResponse
 
equals(Object) - Method in class alluxio.grpc.GetMasterIdPOptions
 
equals(Object) - Method in class alluxio.grpc.GetMasterIdPRequest
 
equals(Object) - Method in class alluxio.grpc.GetMasterIdPResponse
 
equals(Object) - Method in class alluxio.grpc.GetMasterInfoPOptions
 
equals(Object) - Method in class alluxio.grpc.GetMasterInfoPResponse
 
equals(Object) - Method in class alluxio.grpc.GetMetricsPOptions
 
equals(Object) - Method in class alluxio.grpc.GetMetricsPResponse
 
equals(Object) - Method in class alluxio.grpc.GetMountIdPRequest
 
equals(Object) - Method in class alluxio.grpc.GetMountIdPResponse
 
equals(Object) - Method in class alluxio.grpc.GetMountTablePRequest
 
equals(Object) - Method in class alluxio.grpc.GetMountTablePResponse
 
equals(Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
equals(Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
equals(Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
equals(Object) - Method in class alluxio.grpc.GetNodeStatePRequest
 
equals(Object) - Method in class alluxio.grpc.GetNodeStatePResponse
 
equals(Object) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
equals(Object) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
equals(Object) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
equals(Object) - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
equals(Object) - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
equals(Object) - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
equals(Object) - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
equals(Object) - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
equals(Object) - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
equals(Object) - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
equals(Object) - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
equals(Object) - Method in class alluxio.grpc.GetServiceVersionPRequest
 
equals(Object) - Method in class alluxio.grpc.GetServiceVersionPResponse
 
equals(Object) - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
equals(Object) - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
equals(Object) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
equals(Object) - Method in class alluxio.grpc.GetStatusPOptions
 
equals(Object) - Method in class alluxio.grpc.GetStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.GetStatusPResponse
 
equals(Object) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
equals(Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
equals(Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
equals(Object) - Method in class alluxio.grpc.GetUfsInfoPOptions
 
equals(Object) - Method in class alluxio.grpc.GetUfsInfoPRequest
 
equals(Object) - Method in class alluxio.grpc.GetUfsInfoPResponse
 
equals(Object) - Method in class alluxio.grpc.GetUsedBytesPOptions
 
equals(Object) - Method in class alluxio.grpc.GetUsedBytesPResponse
 
equals(Object) - Method in class alluxio.grpc.GetWorkerIdPOptions
 
equals(Object) - Method in class alluxio.grpc.GetWorkerIdPRequest
 
equals(Object) - Method in class alluxio.grpc.GetWorkerIdPResponse
 
equals(Object) - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
equals(Object) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
equals(Object) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
equals(Object) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
equals(Object) - Method in class alluxio.grpc.GetWorkerReportPOptions
 
equals(Object) - Method in class alluxio.grpc.GrpcChannel
 
equals(Object) - Method in class alluxio.grpc.GrpcChannelKey
 
equals(Object) - Method in class alluxio.grpc.GrpcServerAddress
 
equals(Object) - Method in class alluxio.grpc.InconsistentProperties
 
equals(Object) - Method in class alluxio.grpc.InconsistentProperty
 
equals(Object) - Method in class alluxio.grpc.InconsistentPropertyValues
 
equals(Object) - Method in class alluxio.grpc.JobCommand
 
equals(Object) - Method in class alluxio.grpc.JobDescription
 
equals(Object) - Method in class alluxio.grpc.JobHeartbeatPOptions
 
equals(Object) - Method in class alluxio.grpc.JobHeartbeatPRequest
 
equals(Object) - Method in class alluxio.grpc.JobHeartbeatPResponse
 
equals(Object) - Method in class alluxio.grpc.JobInfo
 
equals(Object) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
equals(Object) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
equals(Object) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
equals(Object) - Method in class alluxio.grpc.JobMasterStatus
 
equals(Object) - Method in class alluxio.grpc.JobProgress
 
equals(Object) - Method in class alluxio.grpc.JobProgressPOptions
 
equals(Object) - Method in class alluxio.grpc.JobServiceSummary
 
equals(Object) - Method in class alluxio.grpc.JobStatusBlock
 
equals(Object) - Method in class alluxio.grpc.JobUnused
 
equals(Object) - Method in class alluxio.grpc.JobWorkerHealth
 
equals(Object) - Method in class alluxio.grpc.JournalQueryRequest
 
equals(Object) - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
equals(Object) - Method in class alluxio.grpc.ListAllPOptions
 
equals(Object) - Method in class alluxio.grpc.ListAllPRequest
 
equals(Object) - Method in class alluxio.grpc.ListAllPResponse
 
equals(Object) - Method in class alluxio.grpc.ListPolicyPOptions
 
equals(Object) - Method in class alluxio.grpc.ListPolicyPRequest
 
equals(Object) - Method in class alluxio.grpc.ListPolicyPResponse
 
equals(Object) - Method in class alluxio.grpc.ListProxyStatusPOptions
 
equals(Object) - Method in class alluxio.grpc.ListProxyStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.ListProxyStatusPResponse
 
equals(Object) - Method in class alluxio.grpc.ListStatusPartialPOptions
 
equals(Object) - Method in class alluxio.grpc.ListStatusPartialPRequest
 
equals(Object) - Method in class alluxio.grpc.ListStatusPartialPResponse
 
equals(Object) - Method in class alluxio.grpc.ListStatusPOptions
 
equals(Object) - Method in class alluxio.grpc.ListStatusPRequest
 
equals(Object) - Method in class alluxio.grpc.ListStatusPResponse
 
equals(Object) - Method in class alluxio.grpc.LoadFileFailure
 
equals(Object) - Method in class alluxio.grpc.LoadFileRequest
 
equals(Object) - Method in class alluxio.grpc.LoadFileResponse
 
equals(Object) - Method in class alluxio.grpc.LoadJobPOptions
 
equals(Object) - Method in class alluxio.grpc.LoadMetadataPOptions
 
equals(Object) - Method in class alluxio.grpc.LoadRequest
 
equals(Object) - Method in class alluxio.grpc.LoadResponse
 
equals(Object) - Method in class alluxio.grpc.LocationBlockIdListEntry
 
equals(Object) - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
equals(Object) - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
equals(Object) - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
equals(Object) - Method in class alluxio.grpc.MasterInfo
 
equals(Object) - Method in class alluxio.grpc.MasterVersion
 
equals(Object) - Method in class alluxio.grpc.MessagingRequestHeader
 
equals(Object) - Method in class alluxio.grpc.MessagingResponseHeader
 
equals(Object) - Method in class alluxio.grpc.Metric
 
equals(Object) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
equals(Object) - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
equals(Object) - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
equals(Object) - Method in class alluxio.grpc.MetricValue
 
equals(Object) - Method in class alluxio.grpc.MountPointInfo
 
equals(Object) - Method in class alluxio.grpc.MountPOptions
 
equals(Object) - Method in class alluxio.grpc.MountPRequest
 
equals(Object) - Method in class alluxio.grpc.MountPResponse
 
equals(Object) - Method in class alluxio.grpc.MoveBlockRequest
 
equals(Object) - Method in class alluxio.grpc.MoveBlockResponse
 
equals(Object) - Method in class alluxio.grpc.MoveJobPOptions
 
equals(Object) - Method in class alluxio.grpc.MoveRequest
 
equals(Object) - Method in class alluxio.grpc.MoveResponse
 
equals(Object) - Method in class alluxio.grpc.NeedsSyncRequest
 
equals(Object) - Method in class alluxio.grpc.NeedsSyncResponse
 
equals(Object) - Method in class alluxio.grpc.NetAddress
 
equals(Object) - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
equals(Object) - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
equals(Object) - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
equals(Object) - Method in class alluxio.grpc.OpenFilePOptions
 
equals(Object) - Method in class alluxio.grpc.PAcl
 
equals(Object) - Method in class alluxio.grpc.PAclEntry
 
equals(Object) - Method in class alluxio.grpc.PersistCommandOptions
 
equals(Object) - Method in class alluxio.grpc.PersistFile
 
equals(Object) - Method in class alluxio.grpc.PMode
 
equals(Object) - Method in class alluxio.grpc.PolicyInfo
 
equals(Object) - Method in class alluxio.grpc.PolicyStatus
 
equals(Object) - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
equals(Object) - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
equals(Object) - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
equals(Object) - Method in class alluxio.grpc.ProxyStatus
 
equals(Object) - Method in class alluxio.grpc.QuorumServerInfo
 
equals(Object) - Method in class alluxio.grpc.ReadRequest
 
equals(Object) - Method in class alluxio.grpc.ReadResponse
 
equals(Object) - Method in class alluxio.grpc.RegisterCommand
 
equals(Object) - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
equals(Object) - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
equals(Object) - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
equals(Object) - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
equals(Object) - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
equals(Object) - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
equals(Object) - Method in class alluxio.grpc.RegisterMasterPOptions
 
equals(Object) - Method in class alluxio.grpc.RegisterMasterPRequest
 
equals(Object) - Method in class alluxio.grpc.RegisterMasterPResponse
 
equals(Object) - Method in class alluxio.grpc.RegisterWorkerPOptions
 
equals(Object) - Method in class alluxio.grpc.RegisterWorkerPRequest
 
equals(Object) - Method in class alluxio.grpc.RegisterWorkerPResponse
 
equals(Object) - Method in class alluxio.grpc.RemoveBlockRequest
 
equals(Object) - Method in class alluxio.grpc.RemoveBlockResponse
 
equals(Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
equals(Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
equals(Object) - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
equals(Object) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
equals(Object) - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
equals(Object) - Method in class alluxio.grpc.RemovePolicyPOptions
 
equals(Object) - Method in class alluxio.grpc.RemovePolicyPRequest
 
equals(Object) - Method in class alluxio.grpc.RemovePolicyPResponse
 
equals(Object) - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
equals(Object) - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
equals(Object) - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
equals(Object) - Method in class alluxio.grpc.RenamePOptions
 
equals(Object) - Method in class alluxio.grpc.RenamePRequest
 
equals(Object) - Method in class alluxio.grpc.RenamePResponse
 
equals(Object) - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
equals(Object) - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
equals(Object) - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
equals(Object) - Method in class alluxio.grpc.RetryInfo
 
equals(Object) - Method in class alluxio.grpc.ReverseResolvePRequest
 
equals(Object) - Method in class alluxio.grpc.ReverseResolvePResponse
 
equals(Object) - Method in class alluxio.grpc.Route
 
equals(Object) - Method in class alluxio.grpc.RouteFailure
 
equals(Object) - Method in class alluxio.grpc.RunPOptions
 
equals(Object) - Method in class alluxio.grpc.RunPRequest
 
equals(Object) - Method in class alluxio.grpc.RunPResponse
 
equals(Object) - Method in class alluxio.grpc.RunTaskCommand
 
equals(Object) - Method in class alluxio.grpc.S3SyntaxOptions
 
equals(Object) - Method in class alluxio.grpc.SaslMessage
 
equals(Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
equals(Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
equals(Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
equals(Object) - Method in class alluxio.grpc.SetAclPOptions
 
equals(Object) - Method in class alluxio.grpc.SetAclPRequest
 
equals(Object) - Method in class alluxio.grpc.SetAclPResponse
 
equals(Object) - Method in class alluxio.grpc.SetAttributePOptions
 
equals(Object) - Method in class alluxio.grpc.SetAttributePRequest
 
equals(Object) - Method in class alluxio.grpc.SetAttributePResponse
 
equals(Object) - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
equals(Object) - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
equals(Object) - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
equals(Object) - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
equals(Object) - Method in class alluxio.grpc.SnapshotData
 
equals(Object) - Method in class alluxio.grpc.SnapshotMetadata
 
equals(Object) - Method in class alluxio.grpc.StatusSummary
 
equals(Object) - Method in class alluxio.grpc.StopJobPRequest
 
equals(Object) - Method in class alluxio.grpc.StopJobPResponse
 
equals(Object) - Method in class alluxio.grpc.StorageList
 
equals(Object) - Method in class alluxio.grpc.SubmitJobPRequest
 
equals(Object) - Method in class alluxio.grpc.SubmitJobPResponse
 
equals(Object) - Method in class alluxio.grpc.SubmitOptions
 
equals(Object) - Method in class alluxio.grpc.SubmitRequest
 
equals(Object) - Method in class alluxio.grpc.SubmitResponse
 
equals(Object) - Method in class alluxio.grpc.table.AllOrNoneSet
 
equals(Object) - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
equals(Object) - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
equals(Object) - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
equals(Object) - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
equals(Object) - Method in class alluxio.grpc.table.ColumnStatisticsData
 
equals(Object) - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
equals(Object) - Method in class alluxio.grpc.table.ColumnStatisticsList
 
equals(Object) - Method in class alluxio.grpc.table.Constraint
 
equals(Object) - Method in class alluxio.grpc.table.Database
 
equals(Object) - Method in class alluxio.grpc.table.Date
 
equals(Object) - Method in class alluxio.grpc.table.DateColumnStatsData
 
equals(Object) - Method in class alluxio.grpc.table.Decimal
 
equals(Object) - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
equals(Object) - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
equals(Object) - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
equals(Object) - Method in class alluxio.grpc.table.Domain
 
equals(Object) - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
equals(Object) - Method in class alluxio.grpc.table.EquatableValueSet
 
equals(Object) - Method in class alluxio.grpc.table.FieldSchema
 
equals(Object) - Method in class alluxio.grpc.table.FileStatistics
 
equals(Object) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
equals(Object) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
equals(Object) - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
equals(Object) - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
equals(Object) - Method in class alluxio.grpc.table.GetDatabasePRequest
 
equals(Object) - Method in class alluxio.grpc.table.GetDatabasePResponse
 
equals(Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
equals(Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
equals(Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
equals(Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
equals(Object) - Method in class alluxio.grpc.table.GetTablePRequest
 
equals(Object) - Method in class alluxio.grpc.table.GetTablePResponse
 
equals(Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
equals(Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
equals(Object) - Method in class alluxio.grpc.table.Layout
 
equals(Object) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
equals(Object) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
equals(Object) - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
equals(Object) - Method in class alluxio.grpc.table.layout.hive.Storage
 
equals(Object) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
equals(Object) - Method in class alluxio.grpc.table.LayoutSpec
 
equals(Object) - Method in class alluxio.grpc.table.LongColumnStatsData
 
equals(Object) - Method in class alluxio.grpc.table.Partition
 
equals(Object) - Method in class alluxio.grpc.table.PartitionSpec
 
equals(Object) - Method in class alluxio.grpc.table.Range
 
equals(Object) - Method in class alluxio.grpc.table.RangeSet
 
equals(Object) - Method in class alluxio.grpc.table.ReadTablePRequest
 
equals(Object) - Method in class alluxio.grpc.table.ReadTablePResponse
 
equals(Object) - Method in class alluxio.grpc.table.Schema
 
equals(Object) - Method in class alluxio.grpc.table.StringColumnStatsData
 
equals(Object) - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
equals(Object) - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
equals(Object) - Method in class alluxio.grpc.table.SyncStatus
 
equals(Object) - Method in class alluxio.grpc.table.TableInfo
 
equals(Object) - Method in class alluxio.grpc.table.Transformation
 
equals(Object) - Method in class alluxio.grpc.table.TransformJobInfo
 
equals(Object) - Method in class alluxio.grpc.table.TransformTablePRequest
 
equals(Object) - Method in class alluxio.grpc.table.TransformTablePResponse
 
equals(Object) - Method in class alluxio.grpc.table.Value
 
equals(Object) - Method in class alluxio.grpc.TierList
 
equals(Object) - Method in class alluxio.grpc.TransferLeaderMessage
 
equals(Object) - Method in class alluxio.grpc.TransferLeadershipPOptions
 
equals(Object) - Method in class alluxio.grpc.TransferLeadershipPRequest
 
equals(Object) - Method in class alluxio.grpc.TransferLeadershipPResponse
 
equals(Object) - Method in class alluxio.grpc.TransportMessage
 
equals(Object) - Method in class alluxio.grpc.TriggerPolicyRequest
 
equals(Object) - Method in class alluxio.grpc.TriggerPolicyResponse
 
equals(Object) - Method in class alluxio.grpc.UfsFileStatus
 
equals(Object) - Method in class alluxio.grpc.UfsInfo
 
equals(Object) - Method in class alluxio.grpc.UfsReadOptions
 
equals(Object) - Method in class alluxio.grpc.UfsStatus
 
equals(Object) - Method in class alluxio.grpc.UnmountPOptions
 
equals(Object) - Method in class alluxio.grpc.UnmountPRequest
 
equals(Object) - Method in class alluxio.grpc.UnmountPResponse
 
equals(Object) - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
equals(Object) - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
equals(Object) - Method in class alluxio.grpc.UpdateMountPRequest
 
equals(Object) - Method in class alluxio.grpc.UpdateMountPResponse
 
equals(Object) - Method in class alluxio.grpc.UpdateUfsModePOptions
 
equals(Object) - Method in class alluxio.grpc.UpdateUfsModePRequest
 
equals(Object) - Method in class alluxio.grpc.UpdateUfsModePResponse
 
equals(Object) - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
equals(Object) - Method in class alluxio.grpc.WorkerIdentity
 
equals(Object) - Method in class alluxio.grpc.WorkerInfo
 
equals(Object) - Method in class alluxio.grpc.WorkerLostStorageInfo
 
equals(Object) - Method in class alluxio.grpc.WorkerNetAddress
 
equals(Object) - Method in class alluxio.grpc.WriteOptions
 
equals(Object) - Method in class alluxio.grpc.WriteRequest
 
equals(Object) - Method in class alluxio.grpc.WriteRequestCommand
 
equals(Object) - Method in class alluxio.grpc.WriteResponse
 
equals(Object) - Method in class alluxio.hadoop.AlluxioFileStatus
 
equals(Object) - Method in class alluxio.heartbeat.CronExpressionIntervalSupplier
 
equals(Object) - Method in class alluxio.heartbeat.FixedIntervalSupplier
 
equals(Object) - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
equals(Object) - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
equals(Object) - Method in class alluxio.job.JobDescription
 
equals(Object) - Method in class alluxio.job.plan.BatchedJobConfig
 
equals(Object) - Method in class alluxio.job.plan.meta.PlanInfo
 
equals(Object) - Method in class alluxio.job.plan.migrate.MigrateCommand
 
equals(Object) - Method in class alluxio.job.plan.migrate.MigrateConfig
 
equals(Object) - Method in class alluxio.job.plan.NoopPlanConfig
 
equals(Object) - Method in class alluxio.job.plan.persist.PersistConfig
 
equals(Object) - Method in class alluxio.job.plan.replicate.MoveConfig
 
equals(Object) - Method in class alluxio.job.wire.JobServiceSummary
 
equals(Object) - Method in class alluxio.job.wire.JobWorkerHealth
 
equals(Object) - Method in class alluxio.job.wire.PlanInfo
 
equals(Object) - Method in class alluxio.job.wire.SimpleJobStatusBlock
 
equals(Object) - Method in class alluxio.job.wire.StatusSummary
 
equals(Object) - Method in class alluxio.job.wire.TaskInfo
 
equals(Object) - Method in class alluxio.job.wire.WorkflowInfo
 
equals(Object) - Method in class alluxio.job.workflow.composite.CompositeConfig
 
equals(Object) - Method in class alluxio.master.backcompat.Version
 
equals(Object) - Method in class alluxio.master.block.meta.MasterBlockLocation
 
equals(Object) - Method in class alluxio.master.file.meta.Edge
 
equals(Object) - Method in class alluxio.master.file.meta.Inode
 
equals(Object) - Method in class alluxio.master.file.meta.MutableInode
 
equals(Object) - Method in class alluxio.master.file.meta.options.MountInfo
 
equals(Object) - Method in class alluxio.master.file.meta.TtlBucket
Compares to a specific object.
equals(Object) - Method in class alluxio.master.file.PersistJob
 
equals(Object) - Method in class alluxio.master.job.CopyJob
 
equals(Object) - Method in class alluxio.master.job.DoraLoadJob
 
equals(Object) - Method in class alluxio.master.job.LoadJob
 
equals(Object) - Method in class alluxio.master.job.MoveJob
 
equals(Object) - Method in class alluxio.master.job.plan.PlanCoordinator
 
equals(Object) - Method in class alluxio.master.journal.options.JournalReaderOptions
 
equals(Object) - Method in class alluxio.master.journal.options.JournalWriterOptions
 
equals(Object) - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
equals(Object) - Method in interface alluxio.master.MasterInquireClient.ConnectDetails
 
equals(Object) - Method in class alluxio.master.metrics.MetricsStore.ClusterCounterKey
 
equals(Object) - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
equals(Object) - Method in class alluxio.master.predicate.interval.Interval
 
equals(Object) - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoIdentity
 
equals(Object) - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
equals(Object) - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
equals(Object) - Method in class alluxio.membership.WorkerServiceEntity
 
equals(Object) - Method in class alluxio.metrics.Metric
 
equals(Object) - Method in class alluxio.metrics.MetricKey
 
equals(Object) - Method in class alluxio.metrics.MetricsFilter
 
equals(Object) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
equals(Object) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.Response
 
equals(Object) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
equals(Object) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
equals(Object) - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
equals(Object) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.InodeFileEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.NewBlockEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.PersistFileEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.RenameEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.SetAclEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.StringPairEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
equals(Object) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
equals(Object) - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
equals(Object) - Method in class alluxio.proto.journal.Job.FileFilter
 
equals(Object) - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
equals(Object) - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
equals(Object) - Method in class alluxio.proto.journal.Journal.JournalEntry
 
equals(Object) - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
equals(Object) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
equals(Object) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
equals(Object) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
equals(Object) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
equals(Object) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
equals(Object) - Method in class alluxio.proto.meta.Block.BlockLocation
 
equals(Object) - Method in class alluxio.proto.meta.Block.BlockMeta
 
equals(Object) - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
equals(Object) - Method in class alluxio.proto.meta.InodeMeta.Inode
 
equals(Object) - Method in class alluxio.proto.shared.Acl.AccessControlList
 
equals(Object) - Method in class alluxio.proto.shared.Acl.AclActions
 
equals(Object) - Method in class alluxio.proto.shared.Acl.AclEntry
 
equals(Object) - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
equals(Object) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
equals(Object) - Method in class alluxio.proxy.s3.MultipartUploadCleaner.AbortTask
 
equals(Object) - Method in class alluxio.s3.ListBucketOptions
 
equals(Object) - Method in class alluxio.s3.ListBucketResult.CommonPrefix
 
equals(Object) - Method in class alluxio.scheduler.job.Task
 
equals(Object) - Method in class alluxio.security.authorization.AccessControlList
 
equals(Object) - Method in class alluxio.security.authorization.AclActions
 
equals(Object) - Method in class alluxio.security.authorization.AclEntry
 
equals(Object) - Method in class alluxio.security.authorization.DefaultAccessControlList
 
equals(Object) - Method in class alluxio.security.authorization.ExtendedACLEntries
 
equals(Object) - Method in class alluxio.security.authorization.Mode
 
equals(Object) - Method in class alluxio.security.CurrentUser
 
equals(Object) - Method in class alluxio.security.user.BaseUserState
 
equals(Object) - Method in class alluxio.security.User
 
equals(Object) - Method in class alluxio.SessionInfo
 
equals(Object) - Method in class alluxio.stress.job.StressBenchConfig
 
equals(Object) - Method in class alluxio.stress.worker.IOTaskResult.Point
 
equals(Object) - Method in class alluxio.underfs.AbstractUfsManager.Key
 
equals(Object) - Method in class alluxio.underfs.options.CreateOptions
 
equals(Object) - Method in class alluxio.underfs.options.DeleteOptions
 
equals(Object) - Method in class alluxio.underfs.options.FileLocationOptions
 
equals(Object) - Method in class alluxio.underfs.options.ListOptions
 
equals(Object) - Method in class alluxio.underfs.options.MkdirsOptions
 
equals(Object) - Method in class alluxio.underfs.options.OpenOptions
 
equals(Object) - Method in class alluxio.underfs.UfsStatus
 
equals(Object) - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
equals(Object) - Method in class alluxio.uri.MultiMasterAuthority
 
equals(Object) - Method in class alluxio.uri.MultiPartSchemeURI
 
equals(Object) - Method in class alluxio.uri.NoAuthority
 
equals(Object) - Method in class alluxio.uri.SingleMasterAuthority
 
equals(Object) - Method in class alluxio.uri.StandardURI
 
equals(Object) - Method in class alluxio.uri.UnknownAuthority
 
equals(Object) - Method in class alluxio.uri.ZookeeperAuthority
 
equals(Object) - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
equals(Object) - Method in class alluxio.util.UnixMountInfo
 
equals(Object) - Method in class alluxio.util.UnixMountInfo.Options
 
equals(String, String) - Static method in class alluxio.util.URIUtils
Checks if two (nullable) strings are equal.
equals(Object) - Method in class alluxio.util.WaitForOptions
 
equals(Object) - Method in class alluxio.util.webui.NodeInfo
 
equals(Object) - Method in class alluxio.wire.Address
 
equals(Object) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioMasterInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioProxyInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioWorkerInfo
 
equals(Object) - Method in class alluxio.wire.BlockInfo
 
equals(Object) - Method in class alluxio.wire.BlockLocation
 
equals(Object) - Method in class alluxio.wire.BlockMasterInfo
 
equals(Object) - Method in class alluxio.wire.Capacity
 
equals(Object) - Method in class alluxio.wire.ConfigHash
 
equals(Object) - Method in class alluxio.wire.FileBlockInfo
 
equals(Object) - Method in class alluxio.wire.FileInfo
 
equals(Object) - Method in class alluxio.wire.InconsistentProperty
 
equals(Object) - Method in class alluxio.wire.MasterInfo
 
equals(Object) - Method in class alluxio.wire.MountPointInfo
 
equals(Object) - Method in class alluxio.wire.WorkerIdentity
 
equals(Object) - Method in class alluxio.wire.WorkerInfo
 
equals(Object) - Method in class alluxio.wire.WorkerNetAddress
 
equals(Object) - Method in class alluxio.worker.block.AllocateOptions
 
equals(Object) - Method in class alluxio.worker.block.BlockStoreLocation
Compares to a specific object.
equals(Object) - Method in class alluxio.worker.block.CreateBlockOptions
 
EQUATABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Domain
 
EquatableValueSet - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.EquatableValueSet
EquatableValueSet.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.EquatableValueSet
EquatableValueSetOrBuilder - Interface in alluxio.grpc.table
 
ERANGE() - Static method in class alluxio.jnifuse.ErrorCodes
Math result not representable
EREMCHG() - Static method in class alluxio.jnifuse.ErrorCodes
Remote address changed
EREMOTE() - Static method in class alluxio.jnifuse.ErrorCodes
Object is remote
EREMOTEIO() - Static method in class alluxio.jnifuse.ErrorCodes
Remote I/O error
ERESTART() - Static method in class alluxio.jnifuse.ErrorCodes
Interrupted system call should be restarted
EROFS() - Static method in class alluxio.jnifuse.ErrorCodes
Read-only file system
Errno - Enum in alluxio.jnifuse.constants
 
error(String) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
ErrorCodes - Class in alluxio.jnifuse
 
ErrorInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.ErrorInfo
ErrorInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.ErrorInfo
ErrorInfoOrBuilder - Interface in alluxio.grpc
 
ERRORMESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.ActionInfo
 
ERRORMESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
ERRORMESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
ERRORMSG_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
 
ErrorObject() - Constructor for class alluxio.s3.DeleteObjectsResult.ErrorObject
ErrorResponse(Status.Code, String) - Constructor for class alluxio.RestUtils.ErrorResponse
ERRORS_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigCheckReport
 
ERRORS_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
ErrorType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.ErrorType
ERRORTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.ActionInfo
 
ERRORTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.ErrorInfo
 
ERRORTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
ERRORTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
 
ErrorUtils - Class in alluxio.job
Utility for getting error information in job service.
escape(AlluxioURI) - Static method in class alluxio.metrics.MetricsSystem
Escapes a URI, replacing "/" with "%2F".
ESHUTDOWN() - Static method in class alluxio.jnifuse.ErrorCodes
Cannot send after transport endpoint shutdown
ESOCKTNOSUPPORT() - Static method in class alluxio.jnifuse.ErrorCodes
Socket type not supported
ESPIPE() - Static method in class alluxio.jnifuse.ErrorCodes
Illegal seek
ESRCH() - Static method in class alluxio.jnifuse.ErrorCodes
No such process
ESRMNT() - Static method in class alluxio.jnifuse.ErrorCodes
Srmount error
ESTALE() - Static method in class alluxio.jnifuse.ErrorCodes
Stale file handle
ESTRPIPE() - Static method in class alluxio.jnifuse.ErrorCodes
Streams pipe error
ETAG_XATTR_KEY - Static variable in class alluxio.s3.S3Constants
 
ETCD_ENDPOINTS - Static variable in class alluxio.conf.PropertyKey
 
ETCD_ENDPOINTS - Static variable in class alluxio.conf.PropertyKey.Name
 
EtcdMembershipManager - Class in alluxio.membership
MembershipManager backed by configured etcd cluster.
EtcdMembershipManager(AlluxioConfiguration) - Constructor for class alluxio.membership.EtcdMembershipManager
CTOR for EtcdMembershipManager.
EtcdMembershipManager(AlluxioConfiguration, AlluxioEtcdClient) - Constructor for class alluxio.membership.EtcdMembershipManager
CTOR for EtcdMembershipManager with given AlluxioEtcdClient client.
ETIME() - Static method in class alluxio.jnifuse.ErrorCodes
Timer expired
ETIMEDOUT() - Static method in class alluxio.jnifuse.ErrorCodes
Connection timed out
ETOOMANYREFS() - Static method in class alluxio.jnifuse.ErrorCodes
Too many references: cannot splice
ETXTBSY() - Static method in class alluxio.jnifuse.ErrorCodes
Text file busy
EUCLEAN() - Static method in class alluxio.jnifuse.ErrorCodes
Structure needs cleaning
EUNATCH() - Static method in class alluxio.jnifuse.ErrorCodes
Protocol driver not attached
EUSERS() - Static method in class alluxio.jnifuse.ErrorCodes
Too many users
evaluateResponse(byte[]) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
evict(CacheScope, PageStoreDir) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
evict() - Method in interface alluxio.client.file.cache.evictor.CacheEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.FIFOCacheEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.NondeterministicLRUCacheEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.TwoChoiceRandomEvictor
 
evict() - Method in class alluxio.client.file.cache.evictor.UnevictableCacheEvictor
 
evict(PageStoreDir) - Method in interface alluxio.client.file.cache.PageMetaStore
 
evict(CacheScope, PageStoreDir) - Method in interface alluxio.client.file.cache.PageMetaStore
 
evict(CacheScope, PageStoreDir) - Method in class alluxio.client.file.cache.QuotaPageMetaStore
 
evictByWorkerId(long) - Static method in class alluxio.util.proto.BlockLocationUtils
Evict cache entries by worker id.
evictMatching(Predicate<PageId>) - Method in interface alluxio.client.file.cache.evictor.CacheEvictor
Picks the first candidate for eviction that satisfies the given criterion.
evictMatching(Predicate<PageId>) - Method in class alluxio.client.file.cache.evictor.FIFOCacheEvictor
 
evictMatching(Predicate<PageId>) - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
evictMatching(Predicate<PageId>) - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
evictMatching(Predicate<PageId>) - Method in class alluxio.client.file.cache.evictor.NondeterministicLRUCacheEvictor
 
evictMatching(Predicate<PageId>) - Method in class alluxio.client.file.cache.evictor.TwoChoiceRandomEvictor
 
evictMatching(Predicate<PageId>) - Method in class alluxio.client.file.cache.evictor.UnevictableCacheEvictor
 
EWOULDBLOCK() - Static method in class alluxio.jnifuse.ErrorCodes
Operation would block
exceptionally(Function<Throwable, ? extends T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed when this CompletableFuture completes, with the result of the given function of the exception triggering this CompletableFuture's completion when it completes exceptionally; otherwise, if this CompletableFuture completes normally, then the returned CompletableFuture also completes normally with the same value.
exceptionally(Function<Throwable, ? extends T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes exceptionally, is executed with this stage's exception as the argument to the supplied function.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.network.protocol.RPCMessageDecoder
 
exceptionCaught(Throwable) - Method in interface alluxio.RpcUtils.NettyRPCCallable
Handles exception.
exceptionCaught(Throwable) - Method in interface alluxio.RpcUtils.StreamingRpcCallable
Handles exception.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.worker.http.HttpServerHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.worker.netty.AbstractReadHandler
 
ExceptionMessage - Enum in alluxio.exception
Exception messages used across Alluxio.
ExceptionUtils - Class in alluxio.util
Utility methods for working with exceptions.
exchange(int) - Static method in class alluxio.fuse.AlluxioJniRenameUtils
Checks if the rename flag contains RENAME_EXCHANGE flag.
EXCLUDE_OPTION_NAME - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
 
EXCLUDEMOUNTINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
 
EXDEV() - Static method in class alluxio.jnifuse.ErrorCodes
Cross-device link
exec() - Method in class alluxio.concurrent.jsr.CountedCompleter
Implements execution conventions for CountedCompleters.
exec() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Immediately performs the base action of this task and returns true if, upon return from this method, this task is guaranteed to have completed normally.
execCmdWithBackup(ShellCommand, ShellCommand) - Static method in class alluxio.util.ShellUtils
Executes a shell command.
execCommand(String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command.
execCommandWithOutput(String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command and tolerate non-zero exit code.
execute(ForkJoinTask<?>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
execute(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Convenience method for executing a heartbeat and waiting for it to complete.
execute(Runnable) - Method in class alluxio.master.AlluxioExecutorService
 
execute(Runnable) - Method in class alluxio.master.transport.GrpcMessagingContext
Executes the given callback.
execute(Supplier<T>) - Method in class alluxio.master.transport.GrpcMessagingContext
Executes the given callback.
execute(Runnable) - Method in class alluxio.metrics.InstrumentedExecutorService
 
execute(BlockWorkerClient, WorkerInfo) - Method in class alluxio.scheduler.job.Task
run the task and set the response future.
execute(Runnable) - Method in class alluxio.util.executor.ControllableScheduler
 
EXECUTE_VALUE - Static variable in enum alluxio.grpc.Bits
EXECUTE = 2;
Execute_VALUE - Static variable in enum alluxio.grpc.PAclAction
Execute = 2;
EXECUTE_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclAction
EXECUTE = 2;
ExecuteShellCollectInfoCommand - Class in alluxio.cli.bundler.command
Command to run a set of shell commands to get system information.
ExecuteShellCollectInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
Creates a new instance of ExecuteShellCollectInfoCommand.
executeTask(long, long, RunTaskCommand, RunTaskContext) - Method in class alluxio.worker.job.task.TaskExecutorManager
Executes the given task.
executor(Executor) - Method in class alluxio.grpc.GrpcServerBuilder
Set the executor for this server.
executor() - Method in class alluxio.master.transport.GrpcMessagingContext
 
EXECUTOR_SERVICE_VALUE - Static variable in enum alluxio.grpc.MetricType
EXECUTOR_SERVICE represents an executor service.
executorService(ExecutorService, String) - Static method in class alluxio.metrics.MetricsSystem
Add or replace the instrumented executor service metrics for the given name and executor service.
ExecutorServiceBuilder - Class in alluxio.executor
Used to create ExecutorService instances dynamically by configuration.
ExecutorServiceBuilder() - Constructor for class alluxio.executor.ExecutorServiceBuilder
 
ExecutorServiceBuilder.RpcExecutorHost - Enum in alluxio.executor
Type of Alluxio process for generating RPC ExecutorServices.
ExecutorServiceFactories - Class in alluxio.util.executor
Convenience methods for constructing instances of ExecutorServiceFactory.
ExecutorServiceFactory - Interface in alluxio.util.executor
Interface for a factory which constructs executor services.
ExecutorServiceUtils - Class in alluxio.util.executor
Util class for ExecutorService.
ExecutorServiceUtils() - Constructor for class alluxio.util.executor.ExecutorServiceUtils
 
EXFULL() - Static method in class alluxio.jnifuse.ErrorCodes
Exchange full
exists(ExistsPRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Check if a file or dir exists.
exists(ExistsPRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
exists(String, ExistsPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Check existence of a file or dir.
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
exists(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.exists(AlluxioURI, ExistsPOptions) with default options.
exists(AlluxioURI, ExistsPOptions) - Method in interface alluxio.client.file.FileSystem
Checks whether a path exists in Alluxio space.
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
exists(AlluxioURI, ExistsPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Checks whether a file or directory exists.
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
exists(AlluxioURI, ExistsPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
exists(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
exists(ExistsPRequest, StreamObserver<ExistsPResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Checks the existence of a file or directory.
exists(ExistsPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Checks the existence of a file or directory.
exists(ExistsPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Checks the existence of a file or directory.
exists(ExistsPRequest, StreamObserver<ExistsPResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Checks the existence of a file or directory.
exists(ExistsPRequest, StreamObserver<ExistsPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Checks the existence of the file or directory.
exists(ExistsPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Checks the existence of the file or directory.
exists(ExistsPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Checks the existence of the file or directory.
exists(ExistsPRequest, StreamObserver<ExistsPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Checks the existence of the file or directory.
exists(AlluxioURI, ExistsContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
exists(AlluxioURI, ExistsContext) - Method in interface alluxio.master.file.FileSystemMaster
Checks path exists.
exists(ExistsPRequest, StreamObserver<ExistsPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
EXISTS - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
exists(String, ExistsPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
exists(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
exists(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
exists(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
exists(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
exists(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a file or directory exists in under file system.
exists(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
exists(String) - Static method in class alluxio.util.io.FileUtils
Checks if a path exists.
exists(String, ExistsPOptions) - Method in interface alluxio.worker.dora.DoraWorker
Check existence of a file or dir.
exists(String, ExistsPOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
exists(ExistsPRequest, StreamObserver<ExistsPResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
EXISTS_FIELD_NUMBER - Static variable in class alluxio.grpc.ExistsPResponse
 
EXISTS_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotMetadata
 
ExistsContext - Class in alluxio.master.file.contexts
Used to merge and wrap ExistsPOptions.
existsDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
ExistsPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ExistsPOptions
ExistsPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ExistsPOptions
ExistsPOptionsOrBuilder - Interface in alluxio.grpc
 
ExistsPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ExistsPRequest
ExistsPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ExistsPRequest
ExistsPRequestOrBuilder - Interface in alluxio.grpc
 
ExistsPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ExistsPResponse
ExistsPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ExistsPResponse
ExistsPResponseOrBuilder - Interface in alluxio.grpc
 
existsTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for checking file existence.
EXIT_COLLECT_INFO - Static variable in class alluxio.conf.PropertyKey
 
EXIT_COLLECT_INFO - Static variable in class alluxio.conf.PropertyKey.Name
 
ExitCodeException(int, String) - Constructor for exception alluxio.util.ShellUtils.ExitCodeException
Constructs an ExitCodeException.
expectedFpp() - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
 
expectedFpp() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
EXPIRYMS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetRegisterLeasePResponse
 
ExponentialBackoffRetry - Class in alluxio.retry
Each retry will cause a sleep to happen.
ExponentialBackoffRetry(int, int, int) - Constructor for class alluxio.retry.ExponentialBackoffRetry
Constructs a new retry facility which sleeps for an exponentially increasing amount of time between retries.
ExponentialTimeBoundedRetry - Class in alluxio.retry
A retry policy which uses exponential backoff and a maximum duration time bound.
ExponentialTimeBoundedRetry.Builder - Class in alluxio.retry
Builder for time bounded exponential retry mechanisms.
ExponentialTimer - Class in alluxio.time
The ExponentialTimer can be used for generating a sequence of events that are exponentially distributed in time.
ExponentialTimer(long, long, long, long) - Constructor for class alluxio.time.ExponentialTimer
Creates a new instance of ExponentialTimer.
ExponentialTimer.Result - Enum in alluxio.time
Represents the result of ExponentialTimer.tick().
ExtendedACLEntries - Class in alluxio.security.authorization
Stores the extended ACL entries.
ExtendedACLEntries() - Constructor for class alluxio.security.authorization.ExtendedACLEntries
Creates an empty extended ACL.
ExtendedACLEntries(ExtendedACLEntries) - Constructor for class alluxio.security.authorization.ExtendedACLEntries
Creates a copy.
ExtendedAttribute<T> - Interface in alluxio.master.file.meta.xattr
This class defines an interface for implementing an extended attribute which can be stored on inodes.
ExtendedAttribute.NamespacePrefix - Enum in alluxio.master.file.meta.xattr
The namespace for extended attributes.
EXTENSION_JAR - Static variable in class alluxio.Constants
 
ExtensionFactory<T,S extends AlluxioConfiguration> - Interface in alluxio.extensions
A factory class for creating instance of T based on configuration S.
ExtensionFactoryRegistry<T extends ExtensionFactory<?,S>,S extends AlluxioConfiguration> - Class in alluxio.extensions
An extension registry that uses the ServiceLoader mechanism to automatically discover available factories and provides a central place for obtaining actual extension instances.
ExtensionFactoryRegistry(Class<T>, String) - Constructor for class alluxio.extensions.ExtensionFactoryRegistry
Constructs a registry for loading extension of a particular type.
EXTENSIONS_DIR - Static variable in class alluxio.conf.PropertyKey
 
EXTENSIONS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
ExtensionsClassLoader - Class in alluxio.extensions
An isolated ClassLoader for loading extensions to core Alluxio.
ExtensionsClassLoader(URL[], ClassLoader) - Constructor for class alluxio.extensions.ExtensionsClassLoader
 
ExtensionsShell - Class in alluxio.cli.extensions
Utility for managing Alluxio extensions.
ExtensionUtils - Class in alluxio.util
Utility functions for working with extensions.
External_VALUE - Static variable in enum alluxio.grpc.ErrorType
External = 2;
ExternalProcess - Class in alluxio.multi.process
Class for launching another class in a new processes.
ExternalProcess(Map<PropertyKey, Object>, Class<?>, File) - Constructor for class alluxio.multi.process.ExternalProcess
 
EXTRA_LOADED_FILESYSTEM_CLASSNAME - Static variable in class alluxio.conf.PropertyKey
 
EXTRA_LOADED_FILESYSTEM_CLASSNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
extractAMZHeaders() - Method in class alluxio.proxy.s3.S3Handler
Utility function to help extract x-amz- headers from request.
extractAMZHeaders() - Method in class alluxio.worker.s3.S3NettyHandler
Utility function to help extract x-amz- headers from request.
extractFieldsFromHttpRequestUri(String) - Static method in class alluxio.worker.http.HttpRequestUtil
Parse the HTTP request URI and extract the fields.
extractGroupBits(short) - Static method in class alluxio.security.authorization.Mode
 
extractHiveLayout(Partition) - Static method in class alluxio.table.ProtoUtils
 
extractOtherBits(short) - Static method in class alluxio.security.authorization.Mode
 
extractOwnerBits(short) - Static method in class alluxio.security.authorization.Mode
 

F

FACTORIES - Static variable in interface alluxio.security.user.UserState
An ordered list of factories for creating UserState instances.
Factory() - Constructor for class alluxio.client.block.stream.BlockWorkerClient.Factory
 
Factory(BlockWorker, long, long, InStreamOptions) - Constructor for class alluxio.client.block.stream.BlockWorkerDataReader.Factory
Creates an instance of BlockWorkerDataReader.Factory.
Factory(FileSystemContext, WorkerNetAddress, ReadRequest.Builder) - Constructor for class alluxio.client.block.stream.GrpcDataReader.Factory
Creates an instance of GrpcDataReader.Factory for block reads.
Factory(FileSystemContext, WorkerNetAddress, Protocol.ReadRequest.Builder) - Constructor for class alluxio.client.block.stream.NettyDataReader.Factory
Creates an instance of NettyDataReader.Factory for block reads.
Factory(FileSystemContext, WorkerNetAddress, ReadRequest.Builder, long) - Constructor for class alluxio.client.block.stream.SharedGrpcDataReader.Factory
Creates an instance of SharedGrpcDataReader.Factory for block reads.
Factory(URI) - Constructor for class alluxio.master.journalv0.Journal.Factory
Creates a read-only journal factory with the specified base location.
Factory(URI) - Constructor for class alluxio.master.journalv0.MutableJournal.Factory
Creates a read-write journal factory with the specified base location.
Factory() - Constructor for class alluxio.master.predicate.DatePredicate.Factory
 
Factory() - Constructor for class alluxio.master.predicate.TimePredicate.Factory
 
Factory() - Constructor for class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
 
Factory() - Constructor for class alluxio.master.service.jvmmonitor.JvmMonitorService.Factory
 
Factory() - Constructor for class alluxio.master.service.metrics.MetricsService.Factory
 
Factory() - Constructor for class alluxio.master.service.rpc.RpcServerService.Factory
 
Factory() - Constructor for class alluxio.master.service.web.WebServerService.Factory
 
Factory() - Constructor for class alluxio.membership.MembershipManager.Factory
 
Factory() - Constructor for class alluxio.proxy.s3.RangeFileInStream.Factory
 
Factory() - Constructor for class alluxio.proxy.s3.S3BucketTask.Factory
 
Factory() - Constructor for class alluxio.proxy.s3.S3ObjectTask.Factory
 
Factory() - Constructor for class alluxio.s3.S3RangeSpec.Factory
 
Factory() - Constructor for class alluxio.security.authentication.plain.PlainSaslServer.Factory
Constructs a new PlainSaslServer.Factory for the PlainSaslServer.
Factory() - Constructor for class alluxio.security.group.GroupMappingService.Factory
 
Factory() - Constructor for class alluxio.security.user.NoopUserState.Factory
 
Factory() - Constructor for class alluxio.security.user.SimpleUserState.Factory
 
Factory() - Constructor for class alluxio.security.user.UserState.Factory
 
Factory() - Constructor for class alluxio.util.compression.DirectoryMarshaller.Factory
 
Factory() - Constructor for class alluxio.worker.s3.S3NettyBucketTask.Factory
 
Factory() - Constructor for class alluxio.worker.s3.S3NettyObjectTask.Factory
 
fail(Throwable) - Method in class alluxio.master.file.ListStatusResultStream
Used to fail streaming with an error.
failed(int, long, long) - Method in class alluxio.master.job.JobMaster
 
failed() - Method in class alluxio.master.job.plan.PlanTracker
 
FAILED_PRECONDITION_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
FailedPrecondition indicates operation was rejected because the system is not in a state required for the operation's execution.
Failed_VALUE - Static variable in enum alluxio.grpc.BackupState
Failed = 6;
FAILED_VALUE - Static variable in enum alluxio.grpc.ConfigStatus
FAILED = 3;
FAILED_VALUE - Static variable in enum alluxio.grpc.Status
FAILED = 3;
FAILED_VALUE - Static variable in enum alluxio.proto.journal.Job.PJobState
FAILED = 4;
failedFuture(Throwable) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is already completed exceptionally with the given exception.
FailedPreconditionException - Exception in alluxio.exception.status
Exception indicating that operation was rejected because the system is not in a state required for the operation's execution.
FailedPreconditionException(String) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionException(Throwable) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionException(String, Throwable) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that operation was rejected because the system is not in a state required for the operation's execution.
FailedPreconditionRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.FailedPreconditionRuntimeException
Constructor.
FailedPreconditionRuntimeException(String) - Constructor for exception alluxio.exception.runtime.FailedPreconditionRuntimeException
Constructor.
FailedPreconditionRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.FailedPreconditionRuntimeException
Constructor.
failedStage(Throwable) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletionStage that is already completed exceptionally with the given exception and supports only those methods in interface CompletionStage.
FailedToAcquireRegisterLeaseException - Exception in alluxio.exception
The exception thrown when the worker cannot acquire a registration lease after all the retry attempts have been exhausted.
FailedToAcquireRegisterLeaseException(String) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified detail message.
FailedToAcquireRegisterLeaseException(String, Throwable) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified detail message and cause.
FailedToAcquireRegisterLeaseException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified exception message and multiple parameters.
FailedToAcquireRegisterLeaseException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
failJob(AlluxioRuntimeException) - Method in class alluxio.master.job.CopyJob
Set load state to FAILED with given reason.
failJob(AlluxioRuntimeException) - Method in class alluxio.master.job.DoraLoadJob
Set load state to FAILED with given reason.
failJob(AlluxioRuntimeException) - Method in class alluxio.master.job.LoadJob
Set load state to FAILED with given reason.
failJob(AlluxioRuntimeException) - Method in class alluxio.master.job.MoveJob
Set move state to FAILED with given reason.
failJob(AlluxioRuntimeException) - Method in interface alluxio.scheduler.job.Job
set job as failure with exception.
failTasksForWorker(long) - Method in class alluxio.master.job.plan.PlanCoordinator
Fails any incomplete tasks being run on the specified worker.
FAILURE_HISTORY - Static variable in class alluxio.job.ServiceConstants
 
FAILURE_VALUE - Static variable in enum alluxio.grpc.TaskStatus
FAILURE = 1;
FAILURES_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyResponse
 
FAILURES_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileResponse
 
FAILURES_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveResponse
 
fastCopy(ReadableByteChannel, WritableByteChannel) - Static method in class alluxio.util.io.BufferUtils
An efficient copy between two channels with a fixed-size buffer.
fatalError(Logger, String, Object...) - Static method in class alluxio.ProcessUtils
Logs a fatal error and then exits the system.
fatalError(Logger, Throwable, String, Object...) - Static method in class alluxio.ProcessUtils
Logs a fatal error and then exits the system.
FeatureUtils - Class in alluxio.util
Utilities to detect features that Alluxio is running with.
FeatureUtils() - Constructor for class alluxio.util.FeatureUtils
 
fetchChildrenIfAbsent(RpcContext, AlluxioURI, MountTable, boolean) - Method in class alluxio.underfs.UfsStatusCache
Fetches children of a given alluxio path, stores them in the cache, then returns them.
fetchChildrenIfAbsent(RpcContext, AlluxioURI, MountTable) - Method in class alluxio.underfs.UfsStatusCache
Fetches children of a given alluxio path stores them in the cache, then returns them.
fetchStatusIfAbsent(AlluxioURI, MountTable) - Method in class alluxio.underfs.UfsStatusCache
Attempts to return a status from the cache.
fh - Variable in class alluxio.jnifuse.struct.FuseFileInfo
 
FIELD_READ_RANDOM - Static variable in class alluxio.stress.client.ClientIOParameters
This must match the member name.
FieldIndex<T,V> - Interface in alluxio.collections
An interface representing an index for IndexedSet, each index for this set must implement the interface to define how to get the value of the field chosen as the index.
FIELDRANGES_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerReportPOptions
 
FieldSchema - Class in alluxio.grpc.table
TODO(binfan): remove this proto file.
FieldSchema.Builder - Class in alluxio.grpc.table
TODO(binfan): remove this proto file.
FieldSchemaOrBuilder - Interface in alluxio.grpc.table
 
FIFOCacheEvictor - Class in alluxio.client.file.cache.evictor
Implementation of Evictor using FIFO eviction policy.
FIFOCacheEvictor(CacheEvictorOptions) - Constructor for class alluxio.client.file.cache.evictor.FIFOCacheEvictor
Required constructor.
file(String) - Static method in interface alluxio.client.file.cache.CacheUsage.PartitionDescriptor
Creates a partition for a specific file.
File - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.File
File - Class in alluxio.proto.journal
 
File.ActiveSyncTxIdEntry - Class in alluxio.proto.journal
next available id: 3
File.ActiveSyncTxIdEntry.Builder - Class in alluxio.proto.journal
next available id: 3
File.ActiveSyncTxIdEntryOrBuilder - Interface in alluxio.proto.journal
 
File.AddMountPointEntry - Class in alluxio.proto.journal
next available id: 7
File.AddMountPointEntry.Builder - Class in alluxio.proto.journal
next available id: 7
File.AddMountPointEntryOrBuilder - Interface in alluxio.proto.journal
 
File.AddSyncPointEntry - Class in alluxio.proto.journal
next available id: 3
File.AddSyncPointEntry.Builder - Class in alluxio.proto.journal
next available id: 3
File.AddSyncPointEntryOrBuilder - Interface in alluxio.proto.journal
 
File.AsyncPersistRequestEntry - Class in alluxio.proto.journal
next available id: 2
File.AsyncPersistRequestEntry.Builder - Class in alluxio.proto.journal
next available id: 2
File.AsyncPersistRequestEntryOrBuilder - Interface in alluxio.proto.journal
 
File.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.File
File.CompleteFileEntry - Class in alluxio.proto.journal
next available id: 6
File.CompleteFileEntry.Builder - Class in alluxio.proto.journal
next available id: 6
File.CompleteFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.DeleteFileEntry - Class in alluxio.proto.journal
next available id: 6
File.DeleteFileEntry.Builder - Class in alluxio.proto.journal
next available id: 6
File.DeleteFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.DeleteMountPointEntry - Class in alluxio.proto.journal
next available id: 2
File.DeleteMountPointEntry.Builder - Class in alluxio.proto.journal
next available id: 2
File.DeleteMountPointEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeDirectoryEntry - Class in alluxio.proto.journal
next available id: 21
File.InodeDirectoryEntry.Builder - Class in alluxio.proto.journal
next available id: 21
File.InodeDirectoryEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeDirectoryIdGeneratorEntry - Class in alluxio.proto.journal
next available id: 3
File.InodeDirectoryIdGeneratorEntry.Builder - Class in alluxio.proto.journal
next available id: 3
File.InodeDirectoryIdGeneratorEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeFileEntry - Class in alluxio.proto.journal
next available id: 30
File.InodeFileEntry.Builder - Class in alluxio.proto.journal
next available id: 30
File.InodeFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.InodeLastModificationTimeEntry - Class in alluxio.proto.journal
next available id: 3
File.InodeLastModificationTimeEntry.Builder - Class in alluxio.proto.journal
next available id: 3
File.InodeLastModificationTimeEntryOrBuilder - Interface in alluxio.proto.journal
 
File.NewBlockEntry - Class in alluxio.proto.journal
Creates a new block for a file inode.
File.NewBlockEntry.Builder - Class in alluxio.proto.journal
Creates a new block for a file inode.
File.NewBlockEntryOrBuilder - Interface in alluxio.proto.journal
 
File.PersistDirectoryEntry - Class in alluxio.proto.journal
next available id: 2
File.PersistDirectoryEntry.Builder - Class in alluxio.proto.journal
next available id: 2
File.PersistDirectoryEntryOrBuilder - Interface in alluxio.proto.journal
 
File.PersistFileEntry - Class in alluxio.proto.journal
next available id: 4
File.PersistFileEntry.Builder - Class in alluxio.proto.journal
next available id: 4
File.PersistFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.PSetAclAction - Enum in alluxio.proto.journal
Protobuf enum alluxio.proto.journal.PSetAclAction
File.PTtlAction - Enum in alluxio.proto.journal
Protobuf enum alluxio.proto.journal.PTtlAction
File.RemoveSyncPointEntry - Class in alluxio.proto.journal
next available id: 3
File.RemoveSyncPointEntry.Builder - Class in alluxio.proto.journal
next available id: 3
File.RemoveSyncPointEntryOrBuilder - Interface in alluxio.proto.journal
 
File.RenameEntry - Class in alluxio.proto.journal
next available id: 8
File.RenameEntry.Builder - Class in alluxio.proto.journal
next available id: 8
File.RenameEntryOrBuilder - Interface in alluxio.proto.journal
 
File.SetAclEntry - Class in alluxio.proto.journal
next available id: 6
File.SetAclEntry.Builder - Class in alluxio.proto.journal
next available id: 6
File.SetAclEntryOrBuilder - Interface in alluxio.proto.journal
 
File.SetAttributeEntry - Class in alluxio.proto.journal
next available id: 15
File.SetAttributeEntry.Builder - Class in alluxio.proto.journal
next available id: 15
File.SetAttributeEntryOrBuilder - Interface in alluxio.proto.journal
 
File.StringPairEntry - Class in alluxio.proto.journal
A pair of strings, useful for maps.
File.StringPairEntry.Builder - Class in alluxio.proto.journal
A pair of strings, useful for maps.
File.StringPairEntryOrBuilder - Interface in alluxio.proto.journal
 
File.UfsMode - Enum in alluxio.proto.journal
Protobuf enum alluxio.proto.journal.UfsMode
File.UpdateInodeDirectoryEntry - Class in alluxio.proto.journal
next available id: 5
File.UpdateInodeDirectoryEntry.Builder - Class in alluxio.proto.journal
next available id: 5
File.UpdateInodeDirectoryEntryOrBuilder - Interface in alluxio.proto.journal
 
File.UpdateInodeEntry - Class in alluxio.proto.journal
next available id: 21
File.UpdateInodeEntry.Builder - Class in alluxio.proto.journal
next available id: 21
File.UpdateInodeEntryOrBuilder - Interface in alluxio.proto.journal
 
File.UpdateInodeFileEntry - Class in alluxio.proto.journal
next available id: 13
File.UpdateInodeFileEntry.Builder - Class in alluxio.proto.journal
next available id: 13
File.UpdateInodeFileEntryOrBuilder - Interface in alluxio.proto.journal
 
File.UpdateUfsModeEntry - Class in alluxio.proto.journal
next available id: 3
File.UpdateUfsModeEntry.Builder - Class in alluxio.proto.journal
next available id: 3
File.UpdateUfsModeEntryOrBuilder - Interface in alluxio.proto.journal
 
File.XAttrUpdateStrategy - Enum in alluxio.proto.journal
XAttrUpdateStrategy controls the behaviour for handling updates to the xAttr map - TRUNCATE: Replaces the existing xAttr map with the provided xAttr - UNION_REPLACE: Inserts all keys from xAttr and overwrites any existing keys - UNION_PRESERVE: Inserts all new keys from xAttr (i.e: preserves any existing keys) - DELETE_KEYS: Deletes the specified xAttr keys from the existing xAttr map
FILE_DATE_PATTERN_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPOptions
 
FILE_DIR_PERMISSION_DIFF - Static variable in class alluxio.Constants
 
FILE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileFailure
 
FILE_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
FILE_ID_OPTION - Static variable in class alluxio.cli.fs.command.StatCommand
 
FILE_NAMES_PREFIXES - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
 
FILE_SYSTEM_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
FILE_SYSTEM_MASTER_CLIENT_SERVICE = 1;
FILE_SYSTEM_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_JOB_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_JOB_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
FILE_SYSTEM_MASTER_JOB_SERVICE = 3;
FILE_SYSTEM_MASTER_JOB_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_WORKER_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_WORKER_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
FILE_SYSTEM_MASTER_WORKER_SERVICE = 2;
FILE_SYSTEM_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
 
FILE_SYSTEM_WORKER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_WORKER_NAME - Static variable in class alluxio.Constants
 
FileAlreadyCompletedException - Exception in alluxio.exception
The exception thrown when a file is already completed in Alluxio.
FileAlreadyCompletedException(String) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified detail message.
FileAlreadyCompletedException(String, Throwable) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified detail message and cause.
FileAlreadyCompletedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified exception message and multiple parameters.
FileAlreadyCompletedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileAlreadyExistsException - Exception in alluxio.exception
The exception thrown when a file already exists in Alluxio.
FileAlreadyExistsException(String) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified detail message.
FileAlreadyExistsException(String, Throwable) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified detail message and cause.
FileAlreadyExistsException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified exception message and multiple parameters.
FileAlreadyExistsException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileBlockInfo - Class in alluxio.grpc
Contains the information of a block in a file.
FileBlockInfo - Class in alluxio.wire
The file block information.
FileBlockInfo() - Constructor for class alluxio.wire.FileBlockInfo
Creates a new instance of FileBlockInfo.
FileBlockInfo.Builder - Class in alluxio.grpc
Contains the information of a block in a file.
FileBlockInfoOrBuilder - Interface in alluxio.grpc
 
FILEBLOCKINFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
FILECOUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
 
FILECOUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPResponse
 
FileDoesNotExistException - Exception in alluxio.exception
The exception thrown when a path does not exist in Alluxio.
FileDoesNotExistException(String) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified detail message.
FileDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified detail message and cause.
FileDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
FileDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileDoesNotExistException(AlluxioURI) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception stating that the given path does not exist.
FileFailure - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.FileFailure
FileFailure.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.FileFailure
FileFailureOrBuilder - Interface in alluxio.grpc
 
FileId - Class in alluxio.file
Opaque file identifiers, which are typically a long or a string-based ID.
FILEID_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
FILEID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetFileInfoPRequest
 
FILEID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetFilePathPRequest
 
FILEID_FIELD_NUMBER - Static variable in class alluxio.grpc.PersistFile
 
fileIdFromBlockId(long) - Static method in class alluxio.util.IdUtils
Creates a file ID from a block ID.
FileIncompleteException - Exception in alluxio.exception
The exception thrown when opening a file that hasn't completed.
FileIncompleteException(String) - Constructor for exception alluxio.exception.FileIncompleteException
Constructs a new exception with the specified detail message.
FileIncompleteException(AlluxioURI) - Constructor for exception alluxio.exception.FileIncompleteException
Constructs a new exception stating that the given file is incomplete.
FileInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileInfo
FileInfo - Class in alluxio.wire
The file information.
FileInfo() - Constructor for class alluxio.wire.FileInfo
Creates a new instance of FileInfo.
FileInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileInfo
FILEINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePResponse
 
FILEINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetFileInfoPResponse
 
FILEINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPResponse
 
FILEINFO_FIELD_NUMBER - Static variable in class alluxio.proto.meta.DoraMeta.FileStatus
 
FileInfoOrBuilder - Interface in alluxio.grpc
 
FILEINFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPResponse
 
FILEINFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPResponse
 
FileInStream - Class in alluxio.client.file
A streaming API to read a file.
FileInStream() - Constructor for class alluxio.client.file.FileInStream
 
fileInvalidationBench(InvalidationSyncCacheBench.FileStructure, InvalidationSyncCacheBench.ThreadState) - Method in class alluxio.invalidation.cache.InvalidationSyncCacheBench
 
FileIterable - Class in alluxio.master.job
Iterable for FileInfo objects.
FileIterable(FileSystemMaster, String, Optional<String>, boolean, Predicate<FileInfo>) - Constructor for class alluxio.master.job.FileIterable
Creates a new instance of FileIterable.
FileIterable.FileIterator - Class in alluxio.master.job
An iterator over FileInfo objects.
FileLocation - Class in alluxio.cli.fs.command
Description of the file location.
FileLocation(String, String, boolean, Set<String>) - Constructor for class alluxio.cli.fs.command.FileLocation
Description of the file location.
FileLocationOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
FileOrBuilder - Interface in alluxio.grpc
 
FileOutStream - Class in alluxio.client.file
An abstraction of the output stream API in Alluxio to write data to a file or a block.
FileOutStream() - Constructor for class alluxio.client.file.FileOutStream
 
FilePacketReaderFactory(DoraWorker, FileTransferType) - Constructor for class alluxio.worker.netty.FileReadHandler.FilePacketReaderFactory
Constructor.
FilePartition(String) - Constructor for class alluxio.client.file.cache.CacheUsage.FilePartition
Creates a partition over a file ID.
FILEPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.ActionInfo
 
FILEPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetActionInfoRequest
 
FILEPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.JobStatusBlock
 
FILEPATHFAILED_FIELD_NUMBER - Static variable in class alluxio.grpc.JobStatusBlock
 
FilePredicate - Interface in alluxio.master.predicate
A FilePredicate represents an expression which evaluates to true or false for a file filter.
FilePredicateFactory - Interface in alluxio.master.predicate
A factory for creating file predicates.
FileReadHandler - Class in alluxio.worker.grpc
Handles file read request.
FileReadHandler - Class in alluxio.worker.netty
Handles file read request.
FileReadHandler(ExecutorService, Channel, DoraWorker, FileTransferType) - Constructor for class alluxio.worker.netty.FileReadHandler
Creates an instance of FileReadHandler.
FileReadHandler.FilePacketReader - Class in alluxio.worker.netty
The packet reader to read from a local block worker.
FileReadHandler.FilePacketReaderFactory - Class in alluxio.worker.netty
Factory for creating FileReadHandler.FilePacketReaders.
FILES_SKIPPED_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileResponse
 
FILESIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
 
FileStat - Class in alluxio.jnifuse.struct
 
FileStat(Runtime, ByteBuffer) - Constructor for class alluxio.jnifuse.struct.FileStat
 
FileStatistics - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.FileStatistics
FileStatistics.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.FileStatistics
FileStatisticsOrBuilder - Interface in alluxio.grpc.table
 
FileStatus - Class in alluxio.fuse.file
The file status of ongoing fuse stream.
FileStatus(long) - Constructor for class alluxio.fuse.file.FileStatus
Constructs a new FileStatus.
FileStructure() - Constructor for class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
FileSystem - Interface in alluxio.client.file
Basic file system interface supporting metadata operations and data operations.
FileSystem() - Constructor for class alluxio.fsmaster.FileSystemBench.FileSystem
 
FileSystem() - Constructor for class alluxio.fsmaster.FileSystemMasterBench.FileSystem
 
FileSystem - Class in alluxio.hadoop
An Alluxio client API compatible with Apache Hadoop FileSystem interface.
FileSystem() - Constructor for class alluxio.hadoop.FileSystem
Constructs a new FileSystem.
FileSystem(FileSystem) - Constructor for class alluxio.hadoop.FileSystem
Constructs a new FileSystem instance with a specified FileSystem handler for tests.
FileSystem.Factory - Class in alluxio.client.file
Factory for FileSystem.
FILESYSTEM_CACHE - Static variable in class alluxio.client.file.FileSystem.Factory
 
FileSystemAdminShell - Class in alluxio.cli.fsadmin
Shell for admin to manage file system.
FileSystemAdminShell(AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.FileSystemAdminShell
Construct a new instance of FileSystemAdminShell.
FileSystemAdminShellUtils - Class in alluxio.cli.fsadmin
Class for convenience methods used by FileSystemAdminShell.
FileSystemBase - Class in alluxio.fsmaster
 
FileSystemBase() - Constructor for class alluxio.fsmaster.FileSystemBase
 
FileSystemBase.ServerType - Enum in alluxio.fsmaster
 
FileSystemBench - Class in alluxio.fsmaster
 
FileSystemBench() - Constructor for class alluxio.fsmaster.FileSystemBench
 
FileSystemBench.AlluxioBenchThreadState - Class in alluxio.fsmaster
 
FileSystemBench.AsyncBenchThreadState - Class in alluxio.fsmaster
 
FileSystemBench.BlockingBenchThreadState - Class in alluxio.fsmaster
 
FileSystemBench.FileSystem - Class in alluxio.fsmaster
 
FileSystemBench.HadoopBenchThreadState - Class in alluxio.fsmaster
 
FileSystemBench.ThreadState - Class in alluxio.fsmaster
 
FileSystemCache - Class in alluxio.client.file
A cache for storing FileSystem clients.
FileSystemCache() - Constructor for class alluxio.client.file.FileSystemCache
Constructs a new cache for file system instances.
FileSystemCache.InstanceCachingFileSystem - Class in alluxio.client.file
A wrapper class on a FileSystem instance.
FileSystemCache.Key - Class in alluxio.client.file
A key which can be used to look up a FileSystem instance in the FileSystemCache.
FileSystemCache.Value - Class in alluxio.client.file
A value wraps a FileSystem instance and a ref count in the FileSystemCache.
FileSystemClientType - Enum in alluxio.stress.common
FileSystemClientType, Alluxio Native API or Alluxio HDFS API.
FileSystemCommand - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemCommand
FileSystemCommand - Class in alluxio.wire
Class to represent a FileSystem command.
FileSystemCommand(CommandType, FileSystemCommandOptions) - Constructor for class alluxio.wire.FileSystemCommand
Create a new instance of FileSystemCommand.
FileSystemCommand.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemCommand
FileSystemCommandOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemCommandOptions
FileSystemCommandOptions - Class in alluxio.wire
Class to represent FileSystemCommand options.
FileSystemCommandOptions() - Constructor for class alluxio.wire.FileSystemCommandOptions
Creates a new instance of FileSystemCommandOptions.
FileSystemCommandOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemCommandOptions
FileSystemCommandOptionsOrBuilder - Interface in alluxio.grpc
 
FileSystemCommandOrBuilder - Interface in alluxio.grpc
 
FileSystemCommandUtils - Class in alluxio.cli.fs.command
Common util methods for executing commands.
FileSystemContext - Class in alluxio.client.file
An object which houses resources and information for performing FileSystem operations.
FileSystemContext(AlluxioConfiguration, BlockWorker, List<InetSocketAddress>) - Constructor for class alluxio.client.file.FileSystemContext
Initializes FileSystemContext ID.
FileSystemContext.ClientPoolKey - Class in alluxio.client.file
Key for block worker client pools.
FileSystemContext.FileSystemContextFactory - Class in alluxio.client.file
FileSystemContextFactory, it can be extended.
FileSystemContext.GetWorkerListType - Enum in alluxio.client.file
This enum class is used for specifying the type of worker list to get.
FileSystemContextFactory() - Constructor for class alluxio.client.file.FileSystemContext.FileSystemContextFactory
Default constructor.
FileSystemContextReinitializer - Class in alluxio.client.file
Reinitializes FileSystemContext used by FileSystem.
FileSystemContextReinitializer(FileSystemContext) - Constructor for class alluxio.client.file.FileSystemContextReinitializer
Creates a new reinitializer for the context.
FileSystemContextReinitializer(FileSystemContext, ConfigHashSync) - Constructor for class alluxio.client.file.FileSystemContextReinitializer
Creates a new reinitializer for the context.
FileSystemContextReinitializer.ReinitAllowerResource - Class in alluxio.client.file
This resource allows reinitialization.
FileSystemContextReinitializer.ReinitBlockerResource - Class in alluxio.client.file
This resource blocks reinitialization until close.
fileSystemHeartbeat(FileSystemHeartbeatPRequest, StreamObserver<FileSystemHeartbeatPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
Periodic file system worker heartbeat.
fileSystemHeartbeat(FileSystemHeartbeatPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
Periodic file system worker heartbeat.
fileSystemHeartbeat(FileSystemHeartbeatPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
Periodic file system worker heartbeat.
fileSystemHeartbeat(FileSystemHeartbeatPRequest, StreamObserver<FileSystemHeartbeatPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
Periodic file system worker heartbeat.
fileSystemHeartbeat(FileSystemHeartbeatPRequest, StreamObserver<FileSystemHeartbeatPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
FileSystemHeartbeatPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemHeartbeatPOptions
FileSystemHeartbeatPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemHeartbeatPOptions
FileSystemHeartbeatPOptionsOrBuilder - Interface in alluxio.grpc
 
FileSystemHeartbeatPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemHeartbeatPRequest
FileSystemHeartbeatPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemHeartbeatPRequest
FileSystemHeartbeatPRequestOrBuilder - Interface in alluxio.grpc
 
FileSystemHeartbeatPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemHeartbeatPResponse
FileSystemHeartbeatPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemHeartbeatPResponse
FileSystemHeartbeatPResponseOrBuilder - Interface in alluxio.grpc
 
FileSystemJournalEntryMerger - Class in alluxio.master.file
A file system journal entry merger which merges inode creation and inode update journals on the same inode object into one.
FileSystemJournalEntryMerger() - Constructor for class alluxio.master.file.FileSystemJournalEntryMerger
 
FileSystemMaster - Interface in alluxio.master.file
The interface of file system master service.
FileSystemMasterAuditContext - Class in alluxio.master.file
An audit context for file system master.
FileSystemMasterBase - Class in alluxio.fsmaster
 
FileSystemMasterBase() - Constructor for class alluxio.fsmaster.FileSystemMasterBase
 
FileSystemMasterBench - Class in alluxio.fsmaster
Benchmarks for FileSystemMaster.
FileSystemMasterBench() - Constructor for class alluxio.fsmaster.FileSystemMasterBench
 
FileSystemMasterBench.FileSystem - Class in alluxio.fsmaster
 
FileSystemMasterBench.ThreadState - Class in alluxio.fsmaster
 
FileSystemMasterClient - Interface in alluxio.client.file
A client to use for interacting with a file system master.
FileSystemMasterClient - Class in alluxio.master.file
A wrapper for the gRPC client to interact with the file system master, used by Alluxio job service.
FileSystemMasterClient(MasterClientContext) - Constructor for class alluxio.master.file.FileSystemMasterClient
Creates an instance of FileSystemMasterClient.
FileSystemMasterClient - Class in alluxio.worker.file
A wrapper for the gRPC client to interact with the file system master, used by Alluxio worker.
FileSystemMasterClient(MasterClientContext) - Constructor for class alluxio.worker.file.FileSystemMasterClient
Creates a instance of FileSystemMasterClient.
FileSystemMasterClient.Factory - Class in alluxio.client.file
FileSystemMasterClientPool - Class in alluxio.client.file
A fixed pool of FileSystemMasterClient instances.
FileSystemMasterClientPool(MasterClientContext) - Constructor for class alluxio.client.file.FileSystemMasterClientPool
Creates a new file system master client pool.
FileSystemMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio clients.
FileSystemMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains file system master service endpoints for Alluxio clients.
FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service FileSystemMasterClientService.
FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service FileSystemMasterClientService.
FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service FileSystemMasterClientService.
FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service FileSystemMasterClientService.
FileSystemMasterClientServiceHandler - Class in alluxio.master.file
This class is a gRPC handler for file system master RPCs invoked by an Alluxio client.
FileSystemMasterClientServiceHandler(FileSystemMaster, Scheduler) - Constructor for class alluxio.master.file.FileSystemMasterClientServiceHandler
Creates a new instance of FileSystemMasterClientServiceHandler.
FileSystemMasterClientServiceImplBase() - Constructor for class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase
 
FileSystemMasterCommonPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemMasterCommonPOptions
FileSystemMasterCommonPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FileSystemMasterCommonPOptions
FileSystemMasterCommonPOptionsOrBuilder - Interface in alluxio.grpc
 
FileSystemMasterFactory - Class in alluxio.master.file
Factory to create a FileSystemMaster instance.
FileSystemMasterFactory() - Constructor for class alluxio.master.file.FileSystemMasterFactory
Constructs a new FileSystemMasterFactory.
FileSystemMasterJobServiceGrpc - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterJobServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service FileSystemMasterJobService.
FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service FileSystemMasterJobService.
FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service FileSystemMasterJobService.
FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service FileSystemMasterJobService.
FileSystemMasterJobServiceHandler - Class in alluxio.master.file
This class is a gRPC handler for file system master RPCs invoked by Alluxio job service.
FileSystemMasterJobServiceHandler(FileSystemMaster) - Constructor for class alluxio.master.file.FileSystemMasterJobServiceHandler
Creates a new instance of FileSystemMasterJobServiceHandler.
FileSystemMasterJobServiceImplBase() - Constructor for class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceImplBase
 
FileSystemMasterOptions - Class in alluxio.master.file
The file system class to set default options for master.
FileSystemMasterOptions() - Constructor for class alluxio.master.file.FileSystemMasterOptions
 
FileSystemMasterProto - Class in alluxio.grpc
 
FileSystemMasterView - Class in alluxio.master.file.meta
This class exposes a read-only view of FileSystemMaster.
FileSystemMasterView(FileSystemMaster) - Constructor for class alluxio.master.file.meta.FileSystemMasterView
Constructs a view of the FileSystemMaster.
FileSystemMasterWorkerServiceGrpc - Class in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterWorkerServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains file system master service endpoints for Alluxio workers.
FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service FileSystemMasterWorkerService.
FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service FileSystemMasterWorkerService.
FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service FileSystemMasterWorkerService.
FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service FileSystemMasterWorkerService.
FileSystemMasterWorkerServiceHandler - Class in alluxio.master.file
This class is a gRPC handler for file system master RPCs invoked by an Alluxio worker.
FileSystemMasterWorkerServiceHandler(FileSystemMaster) - Constructor for class alluxio.master.file.FileSystemMasterWorkerServiceHandler
Creates a new instance of FileSystemMasterWorkerServiceHandler.
FileSystemMasterWorkerServiceImplBase() - Constructor for class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceImplBase
 
FileSystemMergeJournalContext - Class in alluxio.master.journal
Context for merging journal entries together for a wrapped journal context.
FileSystemMergeJournalContext(JournalContext, JournalEntryMerger) - Constructor for class alluxio.master.journal.FileSystemMergeJournalContext
FileSystemOptions - Class in alluxio.client.file.options
Options for creating the FileSystem.
FileSystemOptions.Builder - Class in alluxio.client.file.options
Builder for FileSystemOptions.
FileSystemOptionsUtils - Class in alluxio.util
This class contains static methods which can be passed Alluxio configuration objects that will populate the gRPC options objects with the proper values based on the given configuration.
FileSystemOptionsUtils() - Constructor for class alluxio.util.FileSystemOptionsUtils
 
FileSystemParameters - Class in alluxio.stress.common
FileSystem common parameters.
FileSystemParameters() - Constructor for class alluxio.stress.common.FileSystemParameters
 
FileSystemParameters.FileSystemParametersClientTypeConverter - Class in alluxio.stress.common
Converts from String to FileSystemClientType instance.
FileSystemParameters.FileSystemParametersReadTypeConverter - Class in alluxio.stress.common
Converts from String to FileSystemClientType instance.
FileSystemParameters.FileSystemParametersWriteTypeConverter - Class in alluxio.stress.common
Converts from String to a valid FileSystemWriteType String.
FileSystemParametersClientTypeConverter() - Constructor for class alluxio.stress.common.FileSystemParameters.FileSystemParametersClientTypeConverter
 
FileSystemParametersReadTypeConverter() - Constructor for class alluxio.stress.common.FileSystemParameters.FileSystemParametersReadTypeConverter
 
FileSystemParametersWriteTypeConverter() - Constructor for class alluxio.stress.common.FileSystemParameters.FileSystemParametersWriteTypeConverter
 
FileSystemShell - Class in alluxio.cli.fs
Class for handling command line inputs.
FileSystemShell(AlluxioConfiguration) - Constructor for class alluxio.cli.fs.FileSystemShell
Creates a new instance of FileSystemShell.
FileSystemShellUtils - Class in alluxio.cli.fs
Class for convenience methods used by FileSystemShell.
FileSystemUtils - Class in alluxio.client.file
Collection of utility methods to handle with FileSystem related objects.
FileTransferType - Enum in alluxio.network.netty
How a read response will transfer block data over the network.
FileUtils - Class in alluxio.util.io
Provides utility methods for working with files and directories.
FileWriteHandler - Class in alluxio.worker.netty
This handler handles block write request.
FileWriteHandler(ExecutorService, DoraWorker) - Constructor for class alluxio.worker.netty.FileWriteHandler
Creates an instance of FileWriteHandler.
FileWriteHandler.BlockPacketWriter - Class in alluxio.worker.netty
The packet writer that writes to a local block worker.
FileWriterKey(String, String) - Constructor for class alluxio.cli.docgen.MetricsDocGenerator.FileWriterKey
fill(long, long, String, ByteBuffer, long) - Static method in class alluxio.jnifuse.FuseFillDir
 
fill(byte[], int, int) - Method in class alluxio.master.journal.PatchedInputChunked
 
fillStat(AuthPolicy, FileStat, URIStatus) - Static method in class alluxio.fuse.AlluxioFuseUtils
Fills the path status.
fillStat(FileStat, CreateFileStatus) - Static method in class alluxio.fuse.AlluxioFuseUtils
Fills the path status.
filter(ContainerRequestContext) - Method in class alluxio.proxy.s3.logging.RequestLoggingFilter
 
filter(ContainerRequestContext) - Method in class alluxio.proxy.s3.S3AuthenticationFilter
 
FILTER_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPOptions
 
FILTER_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMasterInfoPOptions
 
FILTER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
FILTER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
FILTERS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetBlockMasterInfoPOptions
 
find(String) - Static method in enum alluxio.underfs.hdfs.HdfsVersion
 
find(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds the first Under File System factory that supports the given path.
find(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds the first Under File System factory that supports the given path.
find(String) - Method in class alluxio.worker.dora.DoraOpenFileHandleContainer
Find an open file handle by its key.
findAllFailedPaths() - Method in class alluxio.master.job.tracker.CmdJobTracker
 
findAllWithRecorder(String, S, Recorder) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Finds all the factories that support the given path and record the detailed execution process.
findAllWithRecorder(String, UnderFileSystemConfiguration, Recorder) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds all the Under File System factories that support the given path and record the execution process.
findAndVerify(String, String) - Method in class alluxio.worker.dora.DoraOpenFileHandleContainer
Find an open file handle by its key, and verify against its uuid.
findChildrenMountPoints(AlluxioURI, boolean) - Method in class alluxio.master.file.meta.MountTable
Returns the mount points under the specified path.
findClass(String) - Method in class alluxio.extensions.ExtensionsClassLoader
 
findCmdIds(List<Status>) - Method in class alluxio.master.job.tracker.CmdJobTracker
 
findCredentialPropertyKeys(String) - Static method in class alluxio.conf.CredentialPropertyKeys
 
findFailedPaths(long) - Method in class alluxio.master.job.tracker.CmdJobTracker
 
findJobs(String, List<Status>) - Method in class alluxio.master.job.plan.PlanTracker
 
findJobs(String, List<Status>) - Method in class alluxio.master.job.workflow.WorkflowTracker
 
findLowestCommonAncestor(Collection<AlluxioURI>) - Static method in class alluxio.util.io.PathUtils
 
findTag(int, int) - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
Find a tag in specified bucket and return its position.
findTag(int, int, int) - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
Find a tag in specified two buckets and return its position.
findTag(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
findTag(int, int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
Fingerprint - Class in alluxio.underfs
Fingerprint for a UFS file or directory.
Fingerprint.Tag - Enum in alluxio.underfs
The possible tags within the fingerprint.
Fingerprint.Type - Enum in alluxio.underfs
The possible types of the fingerprint.
fireAndForget(NettyRPCContext, ProtoMessage) - Static method in class alluxio.network.netty.NettyRPC
Sends a request and waits until the request is flushed to network.
fireNext(NettyDataReaderStateMachine.TriggerEvent) - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Helper method to allow firing triggers within state handler methods.
fireNext(TriggerWithParameters1<Arg0T, NettyDataReaderStateMachine.TriggerEvent>, Arg0T) - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Helper method to allow firing triggers within state handler methods.
FIRST_COMPLETED_LOG_NUMBER - Static variable in class alluxio.master.journalv0.ufs.UfsJournal
The log number for the first completed log.
FIRST_TIER - Static variable in class alluxio.Constants
 
firstComplete() - Method in class alluxio.concurrent.jsr.CountedCompleter
If this task's pending count is zero, returns this task; otherwise decrements its pending count and returns null.
FixedIntervalSupplier - Class in alluxio.heartbeat
Fixed interval supplier.
FixedIntervalSupplier(long, Logger) - Constructor for class alluxio.heartbeat.FixedIntervalSupplier
Constructs a new FixedIntervalSupplier.
FixedIntervalSupplier(long) - Constructor for class alluxio.heartbeat.FixedIntervalSupplier
Constructs a new FixedIntervalSupplier.
fixedThreadPool(String, int) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name and number of threads.
fixedThreadPoolExecutorServiceFactory(String, int) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name and number of threads.
flags - Variable in class alluxio.jnifuse.struct.FuseFileInfo
 
flattenEntries(TwoKeyConcurrentMap.TriFunction<K1, K2, V, R>) - Method in class alluxio.collections.TwoKeyConcurrentMap
Flattens the (key1, key2, value) triples according to the given function.
flowControlWindow(int) - Method in class alluxio.grpc.GrpcServerBuilder
Sets flow control window.
flush() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
 
flush() - Method in interface alluxio.client.block.stream.DataWriter
Flushes all the pending chunks.
flush() - Method in class alluxio.client.block.stream.GrpcDataWriter
 
flush() - Method in class alluxio.client.block.stream.NettyDataWriter
 
flush() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
flush() - Method in class alluxio.client.file.DoraFileOutStream
 
flush(String, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
flush() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
flush() - Method in class alluxio.fuse.file.FuseFileInStream
 
flush() - Method in class alluxio.fuse.file.FuseFileOutStream
 
flush() - Method in interface alluxio.fuse.file.FuseFileStream
Flushes the stream.
flush() - Method in class alluxio.fuse.file.FusePositionReader
 
flush() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
flush(String, FuseFileInfo) - Method in class alluxio.fuse.StackFS
 
flush(String, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
flush(long) - Method in class alluxio.master.journal.AsyncJournalWriter
Submits a ticket to flush thread and waits until ticket is served.
flush() - Method in class alluxio.master.journal.FileSystemMergeJournalContext
Merges all journals and then flushes them.
flush() - Method in interface alluxio.master.journal.JournalContext
Flushes all the entries appended by the journal context so far.
flush() - Method in interface alluxio.master.journal.JournalWriter
Flushes all the entries written to the underlying storage.
flush() - Method in class alluxio.master.journal.MasterJournalContext
 
flush() - Method in class alluxio.master.journal.MergeJournalContext
 
flush() - Method in class alluxio.master.journal.MetadataSyncMergeJournalContext
 
flush() - Method in class alluxio.master.journal.NoopJournalContext
 
flush() - Method in class alluxio.master.journal.raft.RaftJournalWriter
 
flush() - Method in interface alluxio.master.journal.sink.JournalSink
Signals the sink that the journal is flushed.
flush() - Method in class alluxio.master.journal.StateChangeJournalContext
 
flush() - Method in class alluxio.master.journal.ufs.UfsJournal
Flushes the journal.
flush() - Method in class alluxio.master.journal.ufs.UfsJournalLogWriter
 
flush(long) - Method in class alluxio.master.journalv0.AsyncJournalWriter
Flushes and waits until the specified counter is flushed to the journal.
flush() - Method in interface alluxio.master.journalv0.JournalOutputStream
Flushes the stream.
flush() - Method in interface alluxio.master.journalv0.JournalWriter
Flushes the current log stream.
flush() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
 
flush() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
flush() - Method in class alluxio.master.metastore.caching.Cache
Flushes all data to the backing store.
flush() - Method in class alluxio.underfs.cephfs.CephOutputStream
 
flush() - Method in class alluxio.underfs.cos.COSOutputStream
Flushes this output stream and forces any buffered output bytes to be written out.
flush() - Method in class alluxio.underfs.gcs.GCSOutputStream
 
flush() - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
 
flush() - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
flush() - Method in interface alluxio.underfs.MultipartUploader
Wait for the ongoing uploads to complete.
flush() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
flush() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
flush() - Method in class alluxio.underfs.obs.OBSOutputStream
Flushes this output stream and forces any buffered output bytes to be written out.
flush() - Method in class alluxio.underfs.oss.OSSOutputStream
Flushes this output stream and forces any buffered output bytes to be written out.
flush() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
FLUSH_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
flushCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
FLUSHED_SIGNAL - Static variable in class alluxio.Constants
 
flushEntries(List<Cache<K, V>.Entry>) - Method in class alluxio.master.metastore.caching.Cache
Attempts to flush the given entries to the backing store.
flushInternal(String, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
flushRequest(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
FOLDER_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
forAddress(GrpcServerAddress, AlluxioConfiguration) - Static method in class alluxio.grpc.GrpcServerBuilder
Create an new instance of GrpcServerBuilder with authentication support.
forAddress(GrpcServerAddress, AuthenticationServer, AlluxioConfiguration) - Static method in class alluxio.grpc.GrpcServerBuilder
Create a new instance of GrpcServerBuilder with authentication support.
FORCED_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePOptions
 
forCreate(long, BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for block create request.
forEach(Consumer<? super T>) - Method in class alluxio.collections.DelegatingSet
 
forEach(BiConsumer<? super PropertyKey, ? super Object>) - Method in class alluxio.conf.AlluxioProperties
Iterates over all the key value pairs and performs the given action.
forgetAllWorkers() - Method in class alluxio.master.block.DefaultBlockMaster
Forces all workers to be lost.
fork() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Arranges to asynchronously execute this task in the pool the current task is running in, if applicable, or using the ForkJoinPool.commonPool() if not ForkJoinTask.inForkJoinPool().
ForkJoinPool - Class in alluxio.concurrent.jsr
An ExecutorService for running ForkJoinTasks.
ForkJoinPool() - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
ForkJoinPool(int) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
Creates a ForkJoinPool with the indicated parallelism level, using defaults for all other parameters (see ForkJoinPool(int, ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean, int, int, int, Predicate, long, TimeUnit)).
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean, int, int, int, Predicate<? super ForkJoinPool>, long, TimeUnit) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
Creates a ForkJoinPool with the given parameters.
ForkJoinPool.AlluxioForkJoinWorkerThreadFactory - Class in alluxio.concurrent.jsr
Default ForkJoinWorkerThreadFactory implementation; creates a new ForkJoinWorkerThread using the system class loader as the thread context class loader.
ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in alluxio.concurrent.jsr
Factory for creating new ForkJoinWorkerThreads.
ForkJoinPool.ManagedBlocker - Interface in alluxio.concurrent.jsr
Interface for extending managed parallelism for tasks running in ForkJoinPools.
ForkJoinPoolHelper - Class in alluxio.concurrent
Provides helpers for working with ForkJoinPool.
ForkJoinPoolHelper() - Constructor for class alluxio.concurrent.ForkJoinPoolHelper
 
ForkJoinTask<V> - Class in alluxio.concurrent.jsr
Abstract base class for tasks that run within a ForkJoinPool.
ForkJoinTask() - Constructor for class alluxio.concurrent.jsr.ForkJoinTask
 
ForkJoinWorkerThread - Class in alluxio.concurrent.jsr
A thread managed by a ForkJoinPool, which executes ForkJoinTasks.
ForkJoinWorkerThread(ForkJoinPool) - Constructor for class alluxio.concurrent.jsr.ForkJoinWorkerThread
Creates a ForkJoinWorkerThread operating in the given pool.
Format - Class in alluxio.cli
Formats the Alluxio file system.
format(Format.Mode, AlluxioConfiguration) - Static method in class alluxio.cli.Format
Formats the Alluxio file system.
format(Object...) - Method in enum alluxio.conf.PropertyKey.Template
Converts a property key template (e.g., PropertyKey.Template.WORKER_TIERED_STORE_LEVEL_ALIAS) to a PropertyKey instance.
format() - Method in interface alluxio.master.journal.JournalSystem
Formats the journal system.
format() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
format() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
format() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
format() - Method in class alluxio.master.journal.ufs.UfsJournal
Formats the journal.
format() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
format() - Method in interface alluxio.master.journalv0.MutableJournal
Formats the journal.
format() - Method in class alluxio.master.journalv0.ufs.UfsMutableJournal
 
Format.Mode - Enum in alluxio.cli
The format mode.
FORMAT_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobProgressPResponse
 
FORMAT_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgressPOptions
 
FORMAT_OPTION - Static variable in class alluxio.cli.fs.command.StatCommand
 
formatAndRestartMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the masters, formats them, and then restarts them.
formatJournal() - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
formatJournal() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
formatJournal() - Method in class alluxio.multi.process.MultiProcessCluster
Formats the cluster journal.
formatLsString(boolean, boolean, boolean, String, String, String, long, long, String, String, String) - Static method in class alluxio.cli.fs.command.LsCommand
Formats the ls result string.
formatMode(short, boolean, boolean) - Static method in class alluxio.util.FormatUtils
Formats digital representation of a model as a human-readable string.
formatStackTrace(Thread) - Static method in class alluxio.util.ThreadUtils
 
formatStackTrace(Throwable) - Static method in class alluxio.util.ThreadUtils
Return formatted stacktrace of Throwable instance.
formatTimeTakenMs(long, String) - Static method in class alluxio.util.FormatUtils
Formats time elapsed since the given start time (in milliseconds).
formatTimeTakenNs(long, String) - Static method in class alluxio.util.FormatUtils
Formats time elapsed since the given start time (in nanoseconds).
FormatUtils - Class in alluxio.util
Utility methods to parse specific formats, print according to specific formats or transform among different formats.
formatValue(Object) - Method in class alluxio.conf.PropertyKey
For each property type, there might be different forms of acceptable input format, convert these acceptable formats to proper internal format.
forMove(BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for moving a block by a client request.
forNumber(int) - Static method in enum alluxio.grpc.BackupState
 
forNumber(int) - Static method in enum alluxio.grpc.Bits
 
forNumber(int) - Static method in enum alluxio.grpc.BlockMasterInfoField
 
forNumber(int) - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
 
forNumber(int) - Static method in enum alluxio.grpc.CommandType
 
forNumber(int) - Static method in enum alluxio.grpc.ConfigStatus
 
forNumber(int) - Static method in enum alluxio.grpc.ErrorType
 
forNumber(int) - Static method in enum alluxio.grpc.JobMasterMetaCommand
 
forNumber(int) - Static method in enum alluxio.grpc.JobProgressReportFormat
 
forNumber(int) - Static method in enum alluxio.grpc.JobSource
 
forNumber(int) - Static method in enum alluxio.grpc.JobType
 
forNumber(int) - Static method in enum alluxio.grpc.JournalDomain
 
forNumber(int) - Static method in enum alluxio.grpc.ListStatusPartialPOptions.OffsetTypeCase
 
forNumber(int) - Static method in enum alluxio.grpc.LoadDescendantPType
 
forNumber(int) - Static method in enum alluxio.grpc.LoadMetadataPType
 
forNumber(int) - Static method in enum alluxio.grpc.MasterInfoField
 
forNumber(int) - Static method in enum alluxio.grpc.MetaCommand
 
forNumber(int) - Static method in enum alluxio.grpc.MetricType
 
forNumber(int) - Static method in enum alluxio.grpc.NodeState
 
forNumber(int) - Static method in enum alluxio.grpc.OperationType
 
forNumber(int) - Static method in enum alluxio.grpc.PAclAction
 
forNumber(int) - Static method in enum alluxio.grpc.PAclEntryType
 
forNumber(int) - Static method in enum alluxio.grpc.QuorumServerState
 
forNumber(int) - Static method in enum alluxio.grpc.ReadPType
 
forNumber(int) - Static method in enum alluxio.grpc.RequestType
 
forNumber(int) - Static method in enum alluxio.grpc.SaslMessageType
 
forNumber(int) - Static method in enum alluxio.grpc.Scope
 
forNumber(int) - Static method in enum alluxio.grpc.ServiceType
 
forNumber(int) - Static method in enum alluxio.grpc.SetAclAction
 
forNumber(int) - Static method in enum alluxio.grpc.Status
 
forNumber(int) - Static method in enum alluxio.grpc.SyncPointStatus
 
forNumber(int) - Static method in enum alluxio.grpc.table.ColumnStatisticsData.DataCase
 
forNumber(int) - Static method in enum alluxio.grpc.table.Domain.ValueSetCase
 
forNumber(int) - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
 
forNumber(int) - Static method in enum alluxio.grpc.table.PrincipalType
 
forNumber(int) - Static method in enum alluxio.grpc.table.TableInfo.TableType
 
forNumber(int) - Static method in enum alluxio.grpc.table.Value.ValueCase
 
forNumber(int) - Static method in enum alluxio.grpc.TaskStatus
 
forNumber(int) - Static method in enum alluxio.grpc.TtlAction
 
forNumber(int) - Static method in enum alluxio.grpc.UfsPMode
 
forNumber(int) - Static method in enum alluxio.grpc.WorkerInfoField
 
forNumber(int) - Static method in enum alluxio.grpc.WorkerRange
 
forNumber(int) - Static method in enum alluxio.grpc.WritePType
 
forNumber(int) - Static method in enum alluxio.grpc.WriteRequest.ValueCase
 
forNumber(int) - Static method in enum alluxio.grpc.XAttrPropagationStrategy
 
forNumber(int) - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
forNumber(int) - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
forNumber(int) - Static method in enum alluxio.proto.journal.File.PSetAclAction
 
forNumber(int) - Static method in enum alluxio.proto.journal.File.PTtlAction
 
forNumber(int) - Static method in enum alluxio.proto.journal.File.UfsMode
 
forNumber(int) - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
 
forNumber(int) - Static method in enum alluxio.proto.journal.Job.PJobState
 
forNumber(int) - Static method in enum alluxio.proto.shared.Acl.AclAction
 
forNumber(int) - Static method in enum alluxio.proto.shared.Acl.AclEntryType
 
forNumber(int) - Static method in enum alluxio.proto.status.Status.PStatus
 
forRequestSpace(long, BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for requesting more space for a block.
forTierMove(BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for moving a block during tier-move task.
free(AlluxioURI, FreePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
free(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.free(AlluxioURI, FreePOptions) with default options.
free(AlluxioURI, FreePOptions) - Method in interface alluxio.client.file.FileSystem
Evicts any data under the given path from Alluxio space, but does not delete the data from the UFS.
free(AlluxioURI, FreePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
free(AlluxioURI, FreePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Frees a file.
free(AlluxioURI, FreePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
free(AlluxioURI, FreePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
free(FreePRequest, StreamObserver<FreePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Frees the given file or directory from Alluxio.
free(FreePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Frees the given file or directory from Alluxio.
free(FreePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Frees the given file or directory from Alluxio.
free(FreePRequest, StreamObserver<FreePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Frees the given file or directory from Alluxio.
free(AlluxioURI, FreeContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
free(AlluxioURI, FreeContext) - Method in interface alluxio.master.file.FileSystemMaster
Frees or evicts all of the blocks of the file from alluxio storage.
free(FreePRequest, StreamObserver<FreePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
FREE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
free(String, FreePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
FREE_BYTES_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
FREE_BYTES = 3;
Free_VALUE - Static variable in enum alluxio.grpc.CommandType
Ask the worker to free files.
FREE_VALUE - Static variable in enum alluxio.grpc.TtlAction
Free the file after TTL expires.
FREE_VALUE - Static variable in enum alluxio.proto.journal.File.PTtlAction
FREE = 1;
FREEBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
FreeCommand - Class in alluxio.cli.fs.command
Frees the given file or folder from Alluxio storage (recursively freeing all children if a folder).
FreeCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.FreeCommand
Constructs a new instance to free the given file or folder from Alluxio.
FreeContext - Class in alluxio.master.file.contexts
Used to merge and wrap FreePOptions.
freeDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
FreePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FreePOptions
FreePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FreePOptions
FreePOptionsOrBuilder - Interface in alluxio.grpc
 
FreePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FreePRequest
FreePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FreePRequest
FreePRequestOrBuilder - Interface in alluxio.grpc
 
FreePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FreePResponse
FreePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.FreePResponse
FreePResponseOrBuilder - Interface in alluxio.grpc
 
freeWorker() - Method in interface alluxio.client.block.stream.BlockWorkerClient
Free this worker.
freeWorker() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
freeWorker(FreeWorkerRequest, StreamObserver<FreeWorkerResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
freeWorker(FreeWorkerRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
freeWorker(FreeWorkerRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
freeWorker(FreeWorkerRequest, StreamObserver<FreeWorkerResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
freeWorker() - Method in interface alluxio.worker.block.BlockWorker
Frees all blocks in the current worker by deleting all block store directories.
FreeWorkerRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.FreeWorkerRequest
FreeWorkerRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.FreeWorkerRequest
FreeWorkerRequestOrBuilder - Interface in alluxio.grpc
 
FreeWorkerResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.FreeWorkerResponse
FreeWorkerResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.FreeWorkerResponse
FreeWorkerResponseOrBuilder - Interface in alluxio.grpc
 
from(RejectedExecutionException) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Wrap a RejectedExecutionException with io.grpc RESOURCE_EXHAUSTED exception.
from(Throwable) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an arbitrary throwable to an Alluxio runtime exception.
from(RuntimeException) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an arbitrary RuntimeException to an Alluxio runtime exception.
from(AlluxioStatusException) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an arbitrary AlluxioStatusException to an Alluxio runtime exception.
from(IOException) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an IOException to a corresponding runtime exception.
from(Status) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an Alluxio exception from status and message representation to native representation.
from(JobDescription) - Static method in class alluxio.job.JobDescription
create a job description from JobDescription proto.
from(String, double, MetricType) - Static method in class alluxio.metrics.Metric
Creates the metric from the full name and the value.
from(AmazonClientException) - Static method in exception alluxio.underfs.s3a.AlluxioS3Exception
Converts an AmazonClientException to a corresponding AlluxioS3Exception.
from(String, AmazonClientException) - Static method in exception alluxio.underfs.s3a.AlluxioS3Exception
Converts an AmazonClientException with errormessage to a corresponding AlluxioS3Exception.
from(ReadRequest) - Static method in class alluxio.wire.BlockReadRequest
Creates an instance of BlockReadRequest.
from(BlockStoreMeta, StorageTierAssoc) - Static method in class alluxio.worker.block.BlockWorkerMetrics
return a new BlockWorkerMetrics form a new BlockStoreMeta.
fromAlluxioException(AlluxioException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked Alluxio exceptions to Alluxio status exceptions.
fromBuilder(PropertyKey.Builder) - Static method in class alluxio.conf.PropertyKey.PropertyCreators
 
fromCheckedException(Throwable) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked throwables to Alluxio status exceptions.
fromCliString(String) - Static method in class alluxio.security.authorization.AclEntry
Creates an AclEntry from a string.
fromCliStringWithoutPermissions(String) - Static method in class alluxio.security.authorization.AclEntry
Creates an AclEntry from a string without permissions.
fromConf(AlluxioConfiguration) - Static method in class alluxio.client.file.options.FileSystemOptions.Builder
Creates new builder from configuration.
fromConfig(AlluxioConfiguration) - Static method in class alluxio.fuse.options.FuseOptions.Builder
Creates a new builder pre-populated with settings from the given configurations.
fromFsProto(FsOpPId) - Static method in class alluxio.wire.OperationId
Creates FsOpId from proto.
fromIOException(IOException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an IOException to a corresponding status exception.
fromJournalEntry(File.InodeDirectoryEntry) - Static method in class alluxio.master.file.meta.MutableInodeDirectory
Converts the entry to an MutableInodeDirectory.
fromJournalEntry(File.InodeFileEntry) - Static method in class alluxio.master.file.meta.MutableInodeFile
Converts the entry to an MutableInodeFile.
fromJournalProto(Journal.JournalOpPId) - Static method in class alluxio.wire.OperationId
Creates FsOpId from proto.
fromJson(String) - Static method in interface alluxio.util.JsonSerializable
 
fromJson(String, T[]) - Static method in interface alluxio.util.JsonSerializable
 
fromListValueMapToSingleValueMap(Map<String, List<String>>) - Static method in class alluxio.s3.NettyRestUtils
Convert MultivaluedMap to a single value map.
fromLong(long) - Static method in enum alluxio.master.journal.checkpoint.CheckpointType
 
fromLong(long) - Method in class alluxio.wire.WorkerIdentity.ParserV0
Parses from a long worker ID.
fromMountEntry(File.AddMountPointEntry) - Static method in class alluxio.grpc.GrpcUtils
Creates mount proto options from File.AddMountPointEntry.
fromMultiValueToSingleValueMap(MultivaluedMap<String, String>, boolean) - Static method in class alluxio.proxy.s3.S3RestUtils
Convert MultivaluedMap to a single value map.
fromMultiValueToSingleValueMap(MultivaluedMap<String, String>, boolean) - Static method in class alluxio.s3.NettyRestUtils
Convert MultivaluedMap to a single value map.
fromProto(WorkerInfoField) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
 
fromProto(WorkerRange) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
 
fromProto(ListStatusPartialPResponse) - Static method in class alluxio.client.file.ListStatusPartialResult
fromProto(ReadPType) - Static method in enum alluxio.client.ReadType
 
fromProto(WritePType) - Static method in enum alluxio.client.WriteType
 
fromProto(PAcl) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(PAclEntry) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(PAclAction) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(PAclEntryType) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(BlockLocation) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(BlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(LoadDescendantPType) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(FileInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(FileBlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(MountPointInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(WorkerInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(WorkerNetAddress) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(JobInfo) - Static method in class alluxio.job.ProtoUtils
 
fromProto(Status) - Static method in class alluxio.job.ProtoUtils
 
fromProto(InodeMeta.InodeOrBuilder) - Static method in class alluxio.master.file.meta.MutableInode
 
fromProto(InodeMeta.InodeOrBuilder) - Static method in class alluxio.master.file.meta.MutableInodeDirectory
 
fromProto(InodeMeta.InodeOrBuilder) - Static method in class alluxio.master.file.meta.MutableInodeFile
 
fromProto(Metric) - Static method in class alluxio.metrics.Metric
Constructs the metric object from the proto format.
fromProto(Status.PStatus) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a Status from a protocol buffer type status.
fromProto(Job.PJobState) - Static method in enum alluxio.scheduler.job.JobState
Convert PJobStatus to JobStatus.
fromProto(Bits) - Static method in enum alluxio.security.authorization.Mode.Bits
 
fromProto(PMode) - Static method in class alluxio.security.authorization.Mode
Creates Mode from proto PMode.
fromProto(UfsStatus) - Static method in class alluxio.underfs.UfsStatus
 
fromProto(Acl.AccessControlList) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclActions) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclAction) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclEntry) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclEntryType) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(File.PSetAclAction) - Static method in class alluxio.util.proto.ProtoUtils
Converts proto type to wire type.
fromProto(Status.PStatus) - Static method in class alluxio.util.proto.ProtoUtils
Creates a Status from a protocol buffer type status.
fromProto(NetAddress) - Static method in class alluxio.wire.Address
Creates a new instance of Address from proto representation.
fromProto(BackupPStatus) - Static method in class alluxio.wire.BackupStatus
 
fromProto(BlockMasterInfoField) - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
fromProto(BlockMasterInfo) - Static method in class alluxio.wire.BlockMasterInfo
Creates a new instance of BlockMasterInfo from a proto representation.
fromProto(ConfigCheckReport) - Static method in class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport from proto representation.
fromProto(GetConfigHashPResponse) - Static method in class alluxio.wire.ConfigHash
 
fromProto(GetConfigurationPResponse) - Static method in class alluxio.wire.Configuration
 
fromProto(InconsistentProperty) - Static method in class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty from proto representation.
fromProto(ConfigProperty) - Static method in class alluxio.wire.Property
 
fromProto(WorkerIdentity) - Static method in class alluxio.wire.WorkerIdentity
Converts from a Protobuf representation.
fromProto(WorkerIdentity) - Static method in class alluxio.wire.WorkerIdentity.Parsers
Parses from a protobuf representation.
fromProtobuf(File.PTtlAction) - Static method in class alluxio.master.ProtobufUtils
Converts Protobuf type to Wire type.
fromShort(short) - Static method in enum alluxio.security.authorization.Mode.Bits
Creates a Mode.Bits from a short.
fromShort(short) - Method in class alluxio.security.authorization.Mode
Sets Mode bits using a digital representation.
fromStatusRuntimeException(StatusRuntimeException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts a gRPC StatusRuntimeException to an Alluxio status exception.
fromString(String) - Static method in enum alluxio.client.ReadType
Creates an instance type from the string.
fromString(String) - Static method in class alluxio.conf.PropertyKey
Parses a string and return its corresponding PropertyKey, throwing exception if no such a property can be found.
fromString(String) - Static method in class alluxio.metrics.MetricKey
Parses a given name and return its corresponding MetricKey, throwing exception if no such a Metric can be found.
fromString(String) - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Creates an instance type from the string.
fromString(String) - Static method in enum alluxio.security.authorization.Mode.Bits
 
fromString(String) - Static method in enum alluxio.stress.client.ClientIOOperation
Creates an instance type from the string.
fromString(String) - Static method in enum alluxio.stress.common.FileSystemClientType
Creates an instance type from the string.
fromString(String) - Static method in interface alluxio.uri.Authority
Gets the Authority object from the input string.
fromStringEntries(String, String, List<String>) - Static method in class alluxio.security.authorization.AccessControlList
Converts a list of string entries into an AccessControlList or a DefaultAccessControlList.
fromThrowable(Throwable) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an arbitrary throwable to an Alluxio status exception.
fromThrowable(Throwable) - Static method in class alluxio.grpc.GrpcExceptionUtils
Converts a throwable to a gRPC exception.
fromUfsException(Exception) - Static method in exception alluxio.underfs.hdfs.AlluxioHdfsException
Converts a Hdfs exception to a corresponding AlluxioHdfsException.
fromURIStatus(URIStatus) - Static method in class alluxio.proxy.s3.ListPartsResult.Part
 
fromUUID(UUID) - Method in class alluxio.wire.WorkerIdentity.ParserV1
Parses from a UUID representation.
fromUUID(String) - Method in class alluxio.wire.WorkerIdentity.ParserV1
Parses a worker identity from a string representation of a UUID.
FsCommonProto - Class in alluxio.grpc
 
FsOpPId - Class in alluxio.grpc
Unique operation id.
FsOpPId.Builder - Class in alluxio.grpc
Unique operation id.
FsOpPIdOrBuilder - Interface in alluxio.grpc
 
FsTestOp - Class in alluxio.master.backcompat
A test operation which only needs the FileSystem client.
FsTestOp() - Constructor for class alluxio.master.backcompat.FsTestOp
 
fullPathExists() - Method in class alluxio.master.file.meta.LockedInodePath
 
funnel(PageId, PrimitiveSink) - Method in enum alluxio.client.file.cache.CacheManagerWithShadowCache.PageIdFunnel
 
Fuse2FuseFileInfo - Class in alluxio.jnifuse.struct
Maps to struct fuse_file_info in /usr/include/fuse/fuse_common.h
Fuse2FuseFileInfo(Runtime, ByteBuffer) - Constructor for class alluxio.jnifuse.struct.Fuse2FuseFileInfo
Creates a FuseFileInfo class matching the struct fuse_file_info in libfuse2.
Fuse3FuseFileInfo - Class in alluxio.jnifuse.struct
Maps to struct fuse_file_info in /usr/include/fuse3/fuse_common.h
Fuse3FuseFileInfo(Runtime, ByteBuffer) - Constructor for class alluxio.jnifuse.struct.Fuse3FuseFileInfo
Creates a FuseFileInfo class matching the struct fuse_file_info in libfuse3.
FUSE_AUTH_POLICY_CLASS - Static variable in class alluxio.conf.PropertyKey
 
FUSE_AUTH_POLICY_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_AUTH_POLICY_CUSTOM_GROUP - Static variable in class alluxio.conf.PropertyKey
 
FUSE_AUTH_POLICY_CUSTOM_GROUP - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_AUTH_POLICY_CUSTOM_USER - Static variable in class alluxio.conf.PropertyKey
 
FUSE_AUTH_POLICY_CUSTOM_USER - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_CACHED_PATH_COUNT - Static variable in class alluxio.metrics.MetricKey
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.conf.PropertyKey
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_CHMOD - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_CHOWN - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_FS_NAME - Static variable in class alluxio.conf.PropertyKey
 
FUSE_FS_NAME - Static variable in class alluxio.conf.PropertyKey.Name
 
fuse_get_context() - Method in class alluxio.jnifuse.LibFuse
 
FUSE_GETATTR - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_JNIFUSE_LIBFUSE_VERSION - Static variable in class alluxio.conf.PropertyKey
 
FUSE_JNIFUSE_LIBFUSE_VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
FUSE_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
fuse_main_real(AbstractFuseFileSystem, int, String[]) - Method in class alluxio.jnifuse.LibFuse
 
FUSE_MAX_READER_CONCURRENCY - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MAX_READER_CONCURRENCY - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_MKDIR - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_MOUNT_ALLUXIO_PATH - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MOUNT_ALLUXIO_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_MOUNT_OPTIONS - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MOUNT_OPTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_POSITION_READ_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_POSITION_READ_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_READ - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_READ_WRITE_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
FUSE_READDIR - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_RENAME - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_RMDIR - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_SPECIAL_COMMAND_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_SPECIAL_COMMAND_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_STAT_CACHE_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
FUSE_STAT_CACHE_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_TOTAL_CALLS - Static variable in class alluxio.metrics.MetricKey
 
FUSE_TRUNCATE - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_UFS_ROOT - Static variable in class alluxio.fuse.options.FuseOptions
The UFS root that Fuse mounts.
FUSE_UMOUNT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
FUSE_UMOUNT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_UNLINK - Static variable in class alluxio.fuse.FuseConstants
 
FUSE_UPDATE_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
FUSE_UPDATE_CHECK_ENABLED - Static variable in class alluxio.fuse.options.FuseOptions
 
FUSE_USER_GROUP_TRANSLATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_USER_GROUP_TRANSLATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_VERSION_OPTION_NAME - Static variable in class alluxio.fuse.options.MountOptions
 
FUSE_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WRITE - Static variable in class alluxio.fuse.FuseConstants
 
FuseCliOptions - Class in alluxio.fuse.options
Fuse command line options.
FuseCliOptions() - Constructor for class alluxio.fuse.options.FuseCliOptions
 
FuseCommand - Interface in alluxio.cli
An interface for all fuse shell commands.
FuseConstants - Class in alluxio.fuse
Constants for FUSE.
FuseConstants() - Constructor for class alluxio.fuse.FuseConstants
 
FuseContext - Class in alluxio.jnifuse.struct
 
FuseContext(Runtime, ByteBuffer) - Constructor for class alluxio.jnifuse.struct.FuseContext
 
FuseException - Exception in alluxio.jnifuse
Exception indicating Fuse errors.
FuseException(String) - Constructor for exception alluxio.jnifuse.FuseException
 
FuseException(String, Throwable) - Constructor for exception alluxio.jnifuse.FuseException
 
FuseFileEntry<T extends FuseFileStream> - Class in alluxio.fuse.file
Convenience class to encapsulate file stream and its information (path, id) for reading or writing alluxio file.
FuseFileEntry(long, String, T, int) - Constructor for class alluxio.fuse.file.FuseFileEntry
Constructs a new FuseFileEntry for an Alluxio file.
FuseFileInfo - Class in alluxio.jnifuse.struct
 
FuseFileInfo(Runtime, ByteBuffer) - Constructor for class alluxio.jnifuse.struct.FuseFileInfo
 
FuseFileInOrOutStream - Class in alluxio.fuse.file
An implementation for FuseFileStream for read only or write only workloads.
FuseFileInStream - Class in alluxio.fuse.file
An implementation for FuseFileStream for read only operations against an Alluxio uri.
FuseFileOutStream - Class in alluxio.fuse.file
An implementation for FuseFileStream for sequential write only operations against an Alluxio uri.
FuseFileStream - Interface in alluxio.fuse.file
This interface should be implemented by all fuse file streams.
FuseFileSystem - Interface in alluxio.jnifuse
 
FuseFillDir - Class in alluxio.jnifuse
 
FuseFillDir() - Constructor for class alluxio.jnifuse.FuseFillDir
 
FuseOptions - Class in alluxio.fuse.options
Options for creating the Fuse filesystem.
FuseOptions(FileSystemOptions, Set<String>, boolean, boolean) - Constructor for class alluxio.fuse.options.FuseOptions
Creates a new instance of FuseOptions.
FuseOptions.Builder - Class in alluxio.fuse.options
Builder for Fuse options.
FusePositionReader - Class in alluxio.fuse.file
FUSE position reader.
FusePositionReadOrOutStream - Class in alluxio.fuse.file
An implementation for FuseFileStream for read only or write only workloads.
FuseReadWriteLockManager - Class in alluxio.fuse.lock
The lock manager to guard Fuse read/write operations.
FuseReadWriteLockManager() - Constructor for class alluxio.fuse.lock.FuseReadWriteLockManager
Constructs a new FuseReadWriteLockManager.
FuseShell - Class in alluxio.cli
Fuse shell to run Fuse special commands.
FuseShell(FileSystem, AlluxioConfiguration) - Constructor for class alluxio.cli.FuseShell
Creates a new instance of FuseShell.
FuseSignalHandler - Class in alluxio.fuse
Respond to the kill command when in mount fuse JVM.
FuseSignalHandler(AlluxioJniFuseFileSystem) - Constructor for class alluxio.fuse.FuseSignalHandler
Constructs the new FuseSignalHandler.
FuseStreamFactory - Interface in alluxio.fuse.file
Factory for FuseFileInStream.
FuseWebServer - Class in alluxio.fuse
Fuse web server.
FuseWebServer(String, InetSocketAddress) - Constructor for class alluxio.fuse.FuseWebServer
Creates a new instance of FuseWebServer.

G

gainPrimacy() - Method in interface alluxio.master.journal.JournalSystem
Transitions the journal to primary mode.
gainPrimacy() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
gainPrimacy() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
gainPrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
Transitions the journal from standby to primary mode.
gainPrimacy() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
GarbageCollectorMXBeanView(GarbageCollectorMXBean) - Constructor for class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
GAUGE_VALUE - Static variable in enum alluxio.grpc.MetricType
GAUGE is the simplest type of metric.
GB - Static variable in class alluxio.Constants
 
GCS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
GCS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
GCS_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
 
GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey
 
GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
GCSInputStream - Class in alluxio.underfs.gcs
A stream for reading a file from GCS.
GCSOutputStream - Class in alluxio.underfs.gcs
A stream for writing a file into GCS.
GCSOutputStream(String, String, GoogleStorageService, List<String>) - Constructor for class alluxio.underfs.gcs.GCSOutputStream
Constructs a new stream for writing a file.
GCSPositionReader - Class in alluxio.underfs.gcs
Implementation of ObjectPositionReader that reads from GCS object store.
GCSPositionReader(GoogleStorageService, String, String, long) - Constructor for class alluxio.underfs.gcs.GCSPositionReader
 
GCSUnderFileSystem - Class in alluxio.underfs.gcs
Google Cloud Storage UnderFileSystem implementation based on the jets3t library.
GCSUnderFileSystem(AlluxioURI, GoogleStorageService, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystem
Constructor for GCSUnderFileSystem.
GCSUnderFileSystemFactory - Class in alluxio.underfs.gcs
GCSUnderFileSystemFactory() - Constructor for class alluxio.underfs.gcs.GCSUnderFileSystemFactory
Constructs a new GCSUnderFileSystemFactory.
GCSUtils - Class in alluxio.underfs.gcs
Util functions for GCS under file system.
GCSV2InputStream - Class in alluxio.underfs.gcs.v2
A stream for reading a file from GCS using Google cloud API (GCS input stream version 2).
GCSV2OutputStream - Class in alluxio.underfs.gcs.v2
A stream for writing a file into GCS using Google cloud API (GCS output stream version 2).
GCSV2OutputStream(String, String, Storage) - Constructor for class alluxio.underfs.gcs.v2.GCSV2OutputStream
Constructs a new stream for writing a file.
GCSV2UnderFileSystem - Class in alluxio.underfs.gcs.v2
GCS FS UnderFileSystem implementation based on the Google cloud storage library.
GCSV2UnderFileSystem(AlluxioURI, Storage, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
Constructor for GCSV2UnderFileSystem.
GeneralBenchSummary<T extends TaskResult> - Class in alluxio.stress.common
abstract class for BenchSummary.
GeneralBenchSummary() - Constructor for class alluxio.stress.common.GeneralBenchSummary
 
GeneralWorker(int, int, int, ByteBuffer, boolean, boolean, String) - Constructor for class alluxio.examples.Performance.GeneralWorker
 
generate() - Static method in class alluxio.cli.docgen.ConfigurationDocGenerator
Generates the configuration docs.
generate() - Static method in class alluxio.cli.docgen.MetricsDocGenerator
Writes the supported files for metrics system docs.
generate(String[]) - Static method in class alluxio.cli.DocGenerator
 
generate(List<? extends Summary>) - Method in class alluxio.stress.client.ClientIOSummary.GraphGenerator
 
generate(List<? extends Summary>) - Method in class alluxio.stress.client.ClientIOTaskResult.GraphGenerator
 
generate(List<? extends Summary>) - Method in class alluxio.stress.GraphGenerator
 
generate(List<? extends Summary>) - Method in class alluxio.stress.worker.IOTaskSummary.GraphGenerator
 
generate(List<? extends Summary>) - Method in class alluxio.stress.worker.WorkerBenchSummary.GraphGenerator
 
generateChildDirACL(Short) - Method in class alluxio.security.authorization.DefaultAccessControlList
Creates a child directory's access ACL and default ACL based on the default ACL.
generateChildFileACL(Short) - Method in class alluxio.security.authorization.DefaultAccessControlList
create a child file 's accessACL based on the default ACL.
generateClientFileInfo(String) - Method in class alluxio.master.file.meta.Inode
 
generateClientFileInfo(String) - Method in interface alluxio.master.file.meta.InodeView
Generates a FileInfo of the file or folder.
generateClientFileInfo(String) - Method in class alluxio.master.file.meta.MutableInode
 
generateClientFileInfo(String) - Method in class alluxio.master.file.meta.MutableInodeDirectory
Generates client file info for a folder.
generateClientFileInfo(String) - Method in class alluxio.master.file.meta.MutableInodeFile
 
generateClientWorkerInfo() - Method in class alluxio.job.MasterWorkerInfo
 
generateJobConfig(String[]) - Method in class alluxio.stress.cli.Benchmark
Generate a StressBenchConfig as the default JobConfig.
generateKey(AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
 
generateOrderedNodeInfos(Collection<WorkerInfo>) - Static method in class alluxio.util.webui.WebUtils
Order the nodes by hostName and generate NodeInfo list for UI display.
generateOutputFile(String, String) - Method in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
Generates the output file for the command to write printouts to.
generateQueryString(Map<String, String>) - Static method in class alluxio.util.URIUtils
Generates a query string from a Map of key/value pairs.
GenerateReport - Class in alluxio.stress.cli.report
Generates a report from summaries.
GenerateReport() - Constructor for class alluxio.stress.cli.report.GenerateReport
Creates an instance.
generateS3ErrorResponse(HttpResponseStatus, String, AsciiString) - Static method in class alluxio.s3.S3ErrorResponse
Generates standard S3 error http response.
generateStateDiagram(Path) - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Generates a diagram describing the state transition in a .dot file.
generateStateDiagram(Path) - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
Generates a diagram describing the state transition in a .dot file.
generateTestFilePaths(Path) - Method in class alluxio.stress.cli.worker.StressWorkerBench
Generates the target file paths in a deterministic manner.
generateThreadName(String, String) - Static method in class alluxio.heartbeat.HeartbeatThread
 
generateWorkerInfo(Set<GetWorkerReportOptions.WorkerInfoField>, WorkerState) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Gets the selected field information for this worker.
get(AlluxioConfiguration) - Static method in class alluxio.client.file.cache.CacheManager.Factory
 
get(PageId, int, byte[], int) - Method in interface alluxio.client.file.cache.CacheManager
Reads the entire page if the queried page is found in the cache, stores the result in buffer.
get(PageId, int, int, byte[], int) - Method in interface alluxio.client.file.cache.CacheManager
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
get(PageId, int, ReadTargetBuffer, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
get(PageId, int, int, byte[], int, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
get(PageId, int, CacheScope) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
get() - Static method in class alluxio.client.file.cache.context.CachePerThreadContext
 
get(PageId, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
 
get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
 
get(PageId, int, CacheScope) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
get(PageId, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
get(PageId, int, byte[], int) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
get(PageId, int, int, byte[], int) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
get(PageId, int, int, byte[], int, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
get(PageId, int, int, ReadTargetBuffer, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
get(PageId, ReadTargetBuffer) - Method in interface alluxio.client.file.cache.PageStore
Gets a page from the store to the destination buffer.
get(PageId, int, int, ReadTargetBuffer) - Method in interface alluxio.client.file.cache.PageStore
Gets part of a page from the store to the destination buffer.
get(PageId, int, int, ReadTargetBuffer, boolean) - Method in interface alluxio.client.file.cache.PageStore
Gets part of a page from the store to the destination buffer.
get(PageId, int, CacheScope) - Method in interface alluxio.client.file.cache.ShadowCacheManager
Reads the entire page and refresh its access time if the queried page is found in the cache.
get(PageId, int, int, ReadTargetBuffer, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
get(PageId, int, int, ReadTargetBuffer, boolean) - Method in class alluxio.client.file.cache.store.MemoryPageStore
 
get(PageId, int, int, ReadTargetBuffer, boolean) - Method in class alluxio.client.file.cache.TimeBoundPageStore
 
get() - Static method in class alluxio.client.file.FileSystem.Factory
 
get(Subject) - Static method in class alluxio.client.file.FileSystem.Factory
Get a FileSystem from the cache with a given subject.
get(Subject, AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystem.Factory
Get a FileSystem from the cache with a given subject.
get(FileSystemCache.Key) - Method in class alluxio.client.file.FileSystemCache
Gets a FileSystem instance from the cache.
get(AlluxioURI) - Method in class alluxio.client.file.MetadataCache
 
get() - Method in class alluxio.CloseableSupplier
 
get(int) - Method in interface alluxio.collections.BitSet
 
get(int) - Method in class alluxio.collections.BuiltinBitSet
 
get(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
get(K, LockMode) - Method in class alluxio.collections.LockPool
Locks the specified key in the specified mode.
get(K, LockMode, boolean) - Method in class alluxio.collections.LockPool
Locks the specified key in the specified mode.
get(int) - Method in class alluxio.collections.UnmodifiableArrayList
 
get() - Method in class alluxio.concurrent.jsr.CompletableFuture
Waits if necessary for this future to complete, and then returns its result.
get(long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
Waits if necessary for at most the given time for this future to complete, and then returns its result, if available.
get() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Waits if necessary for the computation to complete, and then retrieves its result.
get(long, TimeUnit) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey, ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
get(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey, ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get() - Method in class alluxio.conf.Hash
If Hash.markOutdated() is called since last Hash.get(), then the version will be recomputed, otherwise, the internally cached version is returned.
get(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
 
get() - Method in class alluxio.DefaultSupplier
 
get() - Method in class alluxio.fuse.AlluxioFuseUtils.CloseableFuseFileInfo
 
get(long, byte[]) - Method in class alluxio.inode.RocksBenchBase
 
get(long) - Method in class alluxio.job.util.TimeSeries
 
get(int) - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
get(int) - Method in interface alluxio.master.file.meta.InodeLockList
 
get(long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
 
get(long, AlluxioURI, long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
 
get(int) - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
get(long) - Method in interface alluxio.master.file.meta.UfsBlockLocationCache
 
get(long, AlluxioURI, long) - Method in interface alluxio.master.file.meta.UfsBlockLocationCache
If the locations exist in the cache, return them, otherwise, retrieves the block locations from UFS, and caches the result.
get() - Method in class alluxio.master.file.RpcContext
 
get() - Method in interface alluxio.master.journal.JournalContext
 
get() - Method in class alluxio.master.meta.PathProperties
 
get(K, ReadOption) - Method in class alluxio.master.metastore.caching.Cache
Retrieves a value from the cache, loading it from the backing store if necessary.
get(K) - Method in class alluxio.master.metastore.caching.Cache
 
get(long, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
get(long, ReadOption) - Method in interface alluxio.master.metastore.InodeStore
 
get(long, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
get(long) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
get() - Method in class alluxio.master.predicate.DatePredicate
 
get() - Method in interface alluxio.master.predicate.FilePredicate
Get the predicate function from the file predicate.
get() - Method in class alluxio.master.predicate.TimePredicate
 
get(AlluxioConfiguration) - Static method in class alluxio.membership.MembershipManager.Factory
Get or create a MembershipManager instance.
get(Class<W>) - Method in class alluxio.Registry
Convenience method for calling Registry.get(Class, int) with a default timeout.
get(Class<W>, int) - Method in class alluxio.Registry
Attempts to look up the Server for the given class.
get() - Method in class alluxio.resource.CloseableResource
 
get(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the User from the ThreadLocal variable.
get(AlluxioConfiguration) - Static method in class alluxio.security.group.GroupMappingService.Factory
Gets the cached groups mapping service being used to map user-to-groups.
get(AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
Gets an instance for the given UFS URI and configuration, if such exists.
get(AbstractUfsManager.Key) - Method in class alluxio.underfs.AbstractUfsManager
 
get(long) - Method in class alluxio.underfs.AbstractUfsManager
 
get(long) - Method in class alluxio.underfs.JobUfsManager
 
get(long) - Method in interface alluxio.underfs.UfsManager
Gets UFS information from the manager if this mount ID exists, or throws exception otherwise.
get(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
get(long) - Method in class alluxio.underfs.WorkerUfsManager
Gets UFS information from the manager if this mount ID exists, or throws exception otherwise.
get(String, Integer, HttpUtils.IProcessInputStream) - Static method in class alluxio.util.network.HttpUtils
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
get(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
get() - Method in class alluxio.worker.modules.WorkerIdentityProvider
Resolves a worker's identity from the following sources, in the order of preference: Alluxio configuration.
GET_INFO - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
GET_INFO - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
GET_INFO - Static variable in class alluxio.proxy.AlluxioProxyRestServiceHandler
 
GET_INFO - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
GET_STATUS - Static variable in class alluxio.job.ServiceConstants
 
GET_STATUS - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
getAbsolutePath() - Method in class alluxio.util.webui.UIFileInfo
Gets absolute path.
getAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
getAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
getAccessAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
getAccessAclBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
getAccessAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
getAccessAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
getAccessAclOrBuilder() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
getAccessControlException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets access control exception.
getAccessID() - Method in class alluxio.s3.auth.AwsAuthInfo
 
getAccessKeyID() - Method in class alluxio.s3.signature.AwsCredential
 
getAccessMode() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.Bits accessMode = 3;
getAccessMode() - Method in class alluxio.grpc.GetStatusPOptions
optional .alluxio.grpc.Bits accessMode = 3;
getAccessMode() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional .alluxio.grpc.Bits accessMode = 3;
getAcl() - Method in class alluxio.client.file.options.OutStreamOptions
 
getAcl() - Method in class alluxio.client.file.URIStatus
 
getAcl() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
getAcl() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.file.PAcl acl = 27;
getAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.file.PAcl acl = 27;
getAcl() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getACL() - Method in class alluxio.master.file.meta.Inode
 
getACL() - Method in interface alluxio.master.file.meta.InodeView
 
getACL() - Method in class alluxio.master.file.meta.MutableInode
 
getAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
getAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional .alluxio.proto.shared.AccessControlList acl = 6;
getAcl() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 6;
getAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
getAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList acl = 15;
getAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 15;
getAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
getAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional .alluxio.proto.shared.AccessControlList acl = 19;
getAcl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 19;
getAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
getAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional .alluxio.proto.shared.AccessControlList acl = 14;
getAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 14;
getAcl(FileSystem, String) - Method in class alluxio.underfs.hdfs.acl.SupportedHdfsAclProvider
 
getAcl(FileSystem, String) - Method in interface alluxio.underfs.hdfs.HdfsAclProvider
Returns the AccessControlList from an hdfs path.
getAcl(FileSystem, String) - Method in class alluxio.underfs.hdfs.NoopHdfsAclProvider
 
getAcl() - Method in class alluxio.underfs.options.CreateOptions
 
getAcl() - Method in class alluxio.wire.FileInfo
 
getAclBuilder() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
getAclBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
getAclBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
getAclBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
getAclBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
getAclOrBuilder() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
getAclOrBuilder() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.file.PAcl acl = 27;
getAclOrBuilder() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.file.PAcl acl = 27;
getAclOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
getAclOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional .alluxio.proto.shared.AccessControlList acl = 6;
getAclOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 6;
getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList acl = 15;
getAclOrBuilder() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 15;
getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
getAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional .alluxio.proto.shared.AccessControlList acl = 19;
getAclOrBuilder() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 19;
getAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
getAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional .alluxio.proto.shared.AccessControlList acl = 14;
getAclOrBuilder() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 14;
getAclPair(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getAclPair(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getAclPair(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getAclPair(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the ACL and the Default ACL of a file or directory in under file system.
getAclPair(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getAction() - Method in class alluxio.grpc.SetAclPRequest.Builder
the set action to perform
getAction() - Method in class alluxio.grpc.SetAclPRequest
the set action to perform
getAction() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the set action to perform
getAction() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional .alluxio.proto.journal.PSetAclAction action = 3;
getAction() - Method in class alluxio.proto.journal.File.SetAclEntry
optional .alluxio.proto.journal.PSetAclAction action = 3;
getAction() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional .alluxio.proto.journal.PSetAclAction action = 3;
getActionId() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionId = 1;
getActionId() - Method in class alluxio.grpc.ActionInfo
optional string actionId = 1;
getActionId() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionId = 1;
getActionId() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string actionId = 2;
getActionId() - Method in class alluxio.grpc.GetActionInfoRequest
optional string actionId = 2;
getActionId() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string actionId = 2;
getActionIdBytes() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionId = 1;
getActionIdBytes() - Method in class alluxio.grpc.ActionInfo
optional string actionId = 1;
getActionIdBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionId = 1;
getActionIdBytes() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string actionId = 2;
getActionIdBytes() - Method in class alluxio.grpc.GetActionInfoRequest
optional string actionId = 2;
getActionIdBytes() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string actionId = 2;
getActionInfo(GetActionInfoRequest, StreamObserver<GetActionInfoResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
Gets the information of a action
getActionInfo(GetActionInfoRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
Gets the information of a action
getActionInfo(GetActionInfoRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
Gets the information of a action
getActionInfo(GetActionInfoRequest, StreamObserver<GetActionInfoResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
Gets the information of a action
GetActionInfoOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetActionInfoOptions
GetActionInfoOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetActionInfoOptions
GetActionInfoOptionsOrBuilder - Interface in alluxio.grpc
 
GetActionInfoRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetActionInfoRequest
GetActionInfoRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetActionInfoRequest
GetActionInfoRequestOrBuilder - Interface in alluxio.grpc
 
GetActionInfoResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetActionInfoResponse
GetActionInfoResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetActionInfoResponse
GetActionInfoResponseOrBuilder - Interface in alluxio.grpc
 
getActions(int) - Method in class alluxio.grpc.PAclEntry.Builder
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActions(int) - Method in class alluxio.grpc.PAclEntry
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActions(int) - Method in interface alluxio.grpc.PAclEntryOrBuilder
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActions(int) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
repeated .alluxio.proto.shared.AclAction actions = 1;
getActions(int) - Method in class alluxio.proto.shared.Acl.AclActions
repeated .alluxio.proto.shared.AclAction actions = 1;
getActions(int) - Method in interface alluxio.proto.shared.Acl.AclActionsOrBuilder
repeated .alluxio.proto.shared.AclAction actions = 1;
getActions(int) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
repeated .alluxio.proto.shared.AclAction actions = 3;
getActions(int) - Method in class alluxio.proto.shared.Acl.AclEntry
repeated .alluxio.proto.shared.AclAction actions = 3;
getActions(int) - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
repeated .alluxio.proto.shared.AclAction actions = 3;
getActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
getActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions
optional .alluxio.proto.shared.AclActions actions = 2;
getActions() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
optional .alluxio.proto.shared.AclActions actions = 2;
getActions() - Method in class alluxio.security.authorization.AclActions
 
getActions() - Method in class alluxio.security.authorization.AclEntry
 
getActionsBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
getActionsCanceled() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsCanceled = 8;
getActionsCanceled() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsCanceled = 8;
getActionsCanceled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsCanceled = 8;
getActionsCount() - Method in class alluxio.grpc.PAclEntry.Builder
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActionsCount() - Method in class alluxio.grpc.PAclEntry
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActionsCount() - Method in interface alluxio.grpc.PAclEntryOrBuilder
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActionsCount() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
repeated .alluxio.proto.shared.AclAction actions = 1;
getActionsCount() - Method in class alluxio.proto.shared.Acl.AclActions
repeated .alluxio.proto.shared.AclAction actions = 1;
getActionsCount() - Method in interface alluxio.proto.shared.Acl.AclActionsOrBuilder
repeated .alluxio.proto.shared.AclAction actions = 1;
getActionsCount() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
repeated .alluxio.proto.shared.AclAction actions = 3;
getActionsCount() - Method in class alluxio.proto.shared.Acl.AclEntry
repeated .alluxio.proto.shared.AclAction actions = 3;
getActionsCount() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
repeated .alluxio.proto.shared.AclAction actions = 3;
getActionsFailed() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsFailed = 9;
getActionsFailed() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsFailed = 9;
getActionsFailed() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsFailed = 9;
getActionsList() - Method in class alluxio.grpc.PAclEntry.Builder
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActionsList() - Method in class alluxio.grpc.PAclEntry
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActionsList() - Method in interface alluxio.grpc.PAclEntryOrBuilder
repeated .alluxio.grpc.file.PAclAction actions = 3;
getActionsList() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
repeated .alluxio.proto.shared.AclAction actions = 1;
getActionsList() - Method in class alluxio.proto.shared.Acl.AclActions
repeated .alluxio.proto.shared.AclAction actions = 1;
getActionsList() - Method in interface alluxio.proto.shared.Acl.AclActionsOrBuilder
repeated .alluxio.proto.shared.AclAction actions = 1;
getActionsList() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
repeated .alluxio.proto.shared.AclAction actions = 3;
getActionsList() - Method in class alluxio.proto.shared.Acl.AclEntry
repeated .alluxio.proto.shared.AclAction actions = 3;
getActionsList() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
repeated .alluxio.proto.shared.AclAction actions = 3;
getActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
getActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions
optional .alluxio.proto.shared.AclActions actions = 2;
getActionsOrBuilder() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
optional .alluxio.proto.shared.AclActions actions = 2;
getActionsRunning() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsRunning = 6;
getActionsRunning() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsRunning = 6;
getActionsRunning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsRunning = 6;
getActionsScheduled() - Method in class alluxio.grpc.PolicyStatus.Builder
metrics
getActionsScheduled() - Method in class alluxio.grpc.PolicyStatus
metrics
getActionsScheduled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
metrics
getActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsSucceeded = 7;
getActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsSucceeded = 7;
getActionsSucceeded() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsSucceeded = 7;
getActionStatus() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionStatus = 3;
getActionStatus() - Method in class alluxio.grpc.ActionInfo
optional string actionStatus = 3;
getActionStatus() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionStatus = 3;
getActionStatusBytes() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionStatus = 3;
getActionStatusBytes() - Method in class alluxio.grpc.ActionInfo
optional string actionStatus = 3;
getActionStatusBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionStatus = 3;
getActionType() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionType = 2;
getActionType() - Method in class alluxio.grpc.ActionInfo
optional string actionType = 2;
getActionType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionType = 2;
getActionTypeBytes() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionType = 2;
getActionTypeBytes() - Method in class alluxio.grpc.ActionInfo
optional string actionType = 2;
getActionTypeBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionType = 2;
getActiveCount() - Method in class alluxio.master.AlluxioExecutorService
 
getActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
getActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry
action fields.
getActiveSyncTxId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
action fields.
getActiveSyncTxIdBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
getActiveSyncTxIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
getActiveSyncTxIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
action fields.
getActiveSyncTxIdOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
action fields.
getActiveThreadCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of threads that are currently stealing or executing tasks.
getActiveWorkers() - Method in class alluxio.master.scheduler.Scheduler
Get active workers.
getAddedBlocks(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocks(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocks(int) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the list of blocks added by the worker in the heartbeat this report represents.
getAddedBlocksBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksList() - Method in class alluxio.grpc.BlockHeartbeatPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksList() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
Deprecated.
getAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest
Deprecated.
getAddedBlocksOnTiers() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
Deprecated.
getAddedBlocksOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
getAddedBlocksOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
getAddedBlocksOnTiersCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersMap() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersOrDefault(String, TierList) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
getAddedBlocksOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksOrBuilder(int) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddedBlocksOrBuilderList() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddMountPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
getAddPolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
getAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
getAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
getAddQuorumServerRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
getAddQuorumServerRequestBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
getAddQuorumServerRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
getAddQuorumServerRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
getAddQuorumServerRequestOrBuilder() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
getAddress() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
 
getAddress() - Method in class alluxio.grpc.GrpcChannelBuilder
 
getAddress() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
getAddress() - Method in class alluxio.grpc.ProxyStatus
optional .alluxio.grpc.NetAddress address = 1;
getAddress() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional .alluxio.grpc.NetAddress address = 1;
getAddress() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
getAddress() - Method in class alluxio.grpc.WorkerInfo
optional .alluxio.grpc.WorkerNetAddress address = 2;
getAddress() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional .alluxio.grpc.WorkerNetAddress address = 2;
getAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
getAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo
optional .alluxio.grpc.WorkerNetAddress address = 1;
getAddress() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
optional .alluxio.grpc.WorkerNetAddress address = 1;
getAddress() - Method in class alluxio.master.LocalAlluxioMaster
 
getAddress() - Method in class alluxio.master.meta.JobMasterInfo
 
getAddress() - Method in class alluxio.master.meta.MasterInfo
 
getAddress() - Method in class alluxio.master.meta.ProxyInfo
 
getAddress() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
getAddress() - Method in class alluxio.util.webui.UIMasterInfo
Gets master address.
getAddress() - Method in class alluxio.wire.MasterInfo
 
getAddress() - Method in class alluxio.wire.WorkerInfo
 
getAddress() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
getAddress() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getAddress() - Method in interface alluxio.worker.dora.DoraWorker
Get the address of the Dora Worker.
getAddress() - Method in class alluxio.worker.dora.PagedDoraWorker
 
getAddress() - Method in interface alluxio.worker.JobWorkerProcess
 
getAddress() - Method in interface alluxio.worker.WorkerProcess
 
getAddressBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
getAddressBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
getAddressBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
getAddresses() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
getAddresses(int) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
getAddresses(int) - Method in class alluxio.grpc.GetWorkerReportPOptions
addresses are only valid when workerRange is SPECIFIED
getAddresses(int) - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
addresses are only valid when workerRange is SPECIFIED
getAddresses() - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
getAddresses() - Method in class alluxio.grpc.MasterVersion
optional .alluxio.grpc.NetAddress addresses = 1;
getAddresses() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional .alluxio.grpc.NetAddress addresses = 1;
getAddresses() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
getAddressesBuilder() - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
getAddressesBytes(int) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
getAddressesBytes(int) - Method in class alluxio.grpc.GetWorkerReportPOptions
addresses are only valid when workerRange is SPECIFIED
getAddressesBytes(int) - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
addresses are only valid when workerRange is SPECIFIED
getAddressesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
getAddressesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions
addresses are only valid when workerRange is SPECIFIED
getAddressesCount() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
addresses are only valid when workerRange is SPECIFIED
getAddressesList() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
getAddressesList() - Method in class alluxio.grpc.GetWorkerReportPOptions
addresses are only valid when workerRange is SPECIFIED
getAddressesList() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
addresses are only valid when workerRange is SPECIFIED
getAddressesOrBuilder() - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
getAddressesOrBuilder() - Method in class alluxio.grpc.MasterVersion
optional .alluxio.grpc.NetAddress addresses = 1;
getAddressesOrBuilder() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional .alluxio.grpc.NetAddress addresses = 1;
getAddressOrBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
getAddressOrBuilder() - Method in class alluxio.grpc.ProxyStatus
optional .alluxio.grpc.NetAddress address = 1;
getAddressOrBuilder() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional .alluxio.grpc.NetAddress address = 1;
getAddressOrBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
getAddressOrBuilder() - Method in class alluxio.grpc.WorkerInfo
optional .alluxio.grpc.WorkerNetAddress address = 2;
getAddressOrBuilder() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional .alluxio.grpc.WorkerNetAddress address = 2;
getAddressOrBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
getAddressOrBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo
optional .alluxio.grpc.WorkerNetAddress address = 1;
getAddressOrBuilder() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
optional .alluxio.grpc.WorkerNetAddress address = 1;
getAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
getAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
getAddSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
getAddSyncPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
getAddSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
getAddSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
getAddSyncPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
getAdvice() - Method in class alluxio.cli.ValidationTaskResult
 
getAffectedPaths(int) - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
getAffectedPaths(int) - Method in class alluxio.grpc.JobInfo
repeated string affectedPaths = 14;
getAffectedPaths(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated string affectedPaths = 14;
getAffectedPaths() - Method in interface alluxio.job.wire.JobInfo
 
getAffectedPaths() - Method in class alluxio.job.wire.PlanInfo
 
getAffectedPathsBytes(int) - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
getAffectedPathsBytes(int) - Method in class alluxio.grpc.JobInfo
repeated string affectedPaths = 14;
getAffectedPathsBytes(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated string affectedPaths = 14;
getAffectedPathsCount() - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
getAffectedPathsCount() - Method in class alluxio.grpc.JobInfo
repeated string affectedPaths = 14;
getAffectedPathsCount() - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated string affectedPaths = 14;
getAffectedPathsList() - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
getAffectedPathsList() - Method in class alluxio.grpc.JobInfo
repeated string affectedPaths = 14;
getAffectedPathsList() - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated string affectedPaths = 14;
getAge(T) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
Get the item's clock value (age).
getAlgorithm() - Method in class alluxio.s3.signature.SignatureInfo
 
getAlias(int) - Method in class alluxio.DefaultStorageTierAssoc
 
getAlias(int) - Method in interface alluxio.StorageTierAssoc
 
getAliases() - Method in class alluxio.conf.PropertyKey
 
getAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
optional bool all = 1;
getAll() - Method in class alluxio.grpc.table.AllOrNoneSet
optional bool all = 1;
getAll() - Method in interface alluxio.grpc.table.AllOrNoneSetOrBuilder
optional bool all = 1;
getAllDatabases() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getAllDatabases() - Method in interface alluxio.client.table.TableMasterClient
Get a list of all database names.
getAllDatabases(GetAllDatabasesPRequest, StreamObserver<GetAllDatabasesPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Returns all databases in the catalog
getAllDatabases(GetAllDatabasesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Returns all databases in the catalog
getAllDatabases(GetAllDatabasesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Returns all databases in the catalog
getAllDatabases(GetAllDatabasesPRequest, StreamObserver<GetAllDatabasesPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Returns all databases in the catalog
GetAllDatabasesPRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllDatabasesPRequest
GetAllDatabasesPRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllDatabasesPRequest
GetAllDatabasesPRequestOrBuilder - Interface in alluxio.grpc.table
 
GetAllDatabasesPResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllDatabasesPResponse
GetAllDatabasesPResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllDatabasesPResponse
GetAllDatabasesPResponseOrBuilder - Interface in alluxio.grpc.table
 
getAllFailedPaths() - Method in class alluxio.master.job.JobMaster
 
getAllInfo() - Method in class alluxio.master.job.workflow.WorkflowTracker
 
getAllInTopologicalOrder() - Method in class alluxio.collections.DirectedAcyclicGraph
Gets all payloads of the DAG in the topological order.
getAllJobMasterStatus() - Method in class alluxio.master.job.JobMaster
Lists the status of all job masters in the cluster.
getAllLiveServices() - Method in class alluxio.membership.ServiceDiscoveryRecipe
Get all healthy service list.
getAllMasterStatus() - Method in interface alluxio.client.job.JobMasterClient
Gets the status of all job masters in the cluster.
getAllMasterStatus() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getAllMasterStatus(GetAllMasterStatusPRequest, StreamObserver<GetAllMasterStatusPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Lists all job master status.
getAllMasterStatus(GetAllMasterStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Lists all job master status.
getAllMasterStatus(GetAllMasterStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Lists all job master status.
getAllMasterStatus(GetAllMasterStatusPRequest, StreamObserver<GetAllMasterStatusPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Lists all job master status.
getAllMasterStatus(GetAllMasterStatusPRequest, StreamObserver<GetAllMasterStatusPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
GetAllMasterStatusPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllMasterStatusPOptions
GetAllMasterStatusPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllMasterStatusPOptions
GetAllMasterStatusPOptionsOrBuilder - Interface in alluxio.grpc
 
GetAllMasterStatusPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllMasterStatusPRequest
GetAllMasterStatusPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllMasterStatusPRequest
GetAllMasterStatusPRequestOrBuilder - Interface in alluxio.grpc
 
GetAllMasterStatusPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllMasterStatusPResponse
GetAllMasterStatusPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllMasterStatusPResponse
GetAllMasterStatusPResponseOrBuilder - Interface in alluxio.grpc
 
getAllMembers() - Method in class alluxio.membership.EtcdMembershipManager
 
getAllMembers() - Method in class alluxio.membership.MasterMembershipManager
 
getAllMembers() - Method in interface alluxio.membership.MembershipManager
Get all registered worker members.
getAllMembers() - Method in class alluxio.membership.StaticMembershipManager
 
getAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNone() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNone() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneBuilder() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneOrBuilder() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllOrNoneOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
getAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional bool allowed = 2;
getAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional bool allowed = 2;
getAllowed() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional bool allowed = 2;
getAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
optional bool allowedOnStandbyMasters = 2;
getAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest
optional bool allowedOnStandbyMasters = 2;
getAllowedOnStandbyMasters() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
optional bool allowedOnStandbyMasters = 2;
getAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool allowExists = 2;
getAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional bool allowExists = 2;
getAllowExists() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional bool allowExists = 2;
getAllowLeader() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool allowLeader = 3;
getAllowLeader() - Method in class alluxio.grpc.BackupPOptions
optional bool allowLeader = 3;
getAllowLeader() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool allowLeader = 3;
getAllPagesByFileId(String) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
getAllPagesByFileId(String) - Method in interface alluxio.client.file.cache.PageMetaStore
Gets all pages by the specified File ID.
getAllTables(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getAllTables(String) - Method in interface alluxio.client.table.TableMasterClient
Get a list of all table names.
getAllTables(GetAllTablesPRequest, StreamObserver<GetAllTablesPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Returns all tables in the database
getAllTables(GetAllTablesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Returns all tables in the database
getAllTables(GetAllTablesPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Returns all tables in the database
getAllTables(GetAllTablesPRequest, StreamObserver<GetAllTablesPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Returns all tables in the database
GetAllTablesPRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllTablesPRequest
GetAllTablesPRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllTablesPRequest
GetAllTablesPRequestOrBuilder - Interface in alluxio.grpc.table
 
GetAllTablesPResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllTablesPResponse
GetAllTablesPResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetAllTablesPResponse
GetAllTablesPResponseOrBuilder - Interface in alluxio.grpc.table
 
getAllThroughput() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getAllTransformJobInfo() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getAllTransformJobInfo() - Method in interface alluxio.client.table.TableMasterClient
 
getAlluxioFileName(String) - Static method in class alluxio.hadoop.HadoopUtils
Given a String path, returns an equivalent Alluxio path.
getAlluxioFuseSpecificMountOptionKeys() - Method in class alluxio.fuse.options.MountOptions
A set recognized option keys.
getAlluxioHome() - Method in class alluxio.master.LocalAlluxioCluster
 
getAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool alluxioOnly = 2;
getAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions
optional bool alluxioOnly = 2;
getAlluxioOnly() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool alluxioOnly = 2;
getAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, this field is about whether to delete in the UFS.
getAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry
Deprecated, this field is about whether to delete in the UFS.
getAlluxioOnly() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
Deprecated, this field is about whether to delete in the UFS.
getAlluxioOptions() - Method in class alluxio.fuse.options.MountOptions
 
getAlluxioPath() - Method in class alluxio.grpc.File.Builder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.grpc.File
optional string alluxio_path = 1;
getAlluxioPath() - Method in interface alluxio.grpc.FileOrBuilder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.grpc.MountPRequest.Builder
the path of alluxio mount point
getAlluxioPath() - Method in class alluxio.grpc.MountPRequest
the path of alluxio mount point
getAlluxioPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
the path of alluxio mount point
getAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
optional string alluxioPath = 1;
getAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse
optional string alluxioPath = 1;
getAlluxioPath() - Method in interface alluxio.grpc.ReverseResolvePResponseOrBuilder
optional string alluxioPath = 1;
getAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest.Builder
the path of the alluxio mount point
getAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest
the path of the alluxio mount point
getAlluxioPath() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
the path of the alluxio mount point
getAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
the path of alluxio mount point
getAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest
the path of alluxio mount point
getAlluxioPath() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
the path of alluxio mount point
getAlluxioPath(Path) - Method in class alluxio.hadoop.AbstractFileSystem
Used to convert hadoop path to Alluxio path.
getAlluxioPath(Path) - Method in class alluxio.hadoop.FileSystem
 
getAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string alluxio_path = 1;
getAlluxioPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
optional string alluxio_path = 1;
getAlluxioPath() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioPath() - Method in class alluxio.worker.block.CreateBlockOptions
 
getAlluxioPathBytes() - Method in class alluxio.grpc.File.Builder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.grpc.File
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in interface alluxio.grpc.FileOrBuilder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.grpc.MountPRequest.Builder
the path of alluxio mount point
getAlluxioPathBytes() - Method in class alluxio.grpc.MountPRequest
the path of alluxio mount point
getAlluxioPathBytes() - Method in interface alluxio.grpc.MountPRequestOrBuilder
the path of alluxio mount point
getAlluxioPathBytes() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
optional string alluxioPath = 1;
getAlluxioPathBytes() - Method in class alluxio.grpc.ReverseResolvePResponse
optional string alluxioPath = 1;
getAlluxioPathBytes() - Method in interface alluxio.grpc.ReverseResolvePResponseOrBuilder
optional string alluxioPath = 1;
getAlluxioPathBytes() - Method in class alluxio.grpc.UnmountPRequest.Builder
the path of the alluxio mount point
getAlluxioPathBytes() - Method in class alluxio.grpc.UnmountPRequest
the path of the alluxio mount point
getAlluxioPathBytes() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
the path of the alluxio mount point
getAlluxioPathBytes() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
the path of alluxio mount point
getAlluxioPathBytes() - Method in class alluxio.grpc.UpdateMountPRequest
the path of alluxio mount point
getAlluxioPathBytes() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
the path of alluxio mount point
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
optional string alluxio_path = 1;
getAlluxioPathBytes() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
optional string alluxio_path = 1;
getAlluxioStorageType() - Method in class alluxio.client.file.options.OutStreamOptions
 
getAlluxioStorageType() - Method in enum alluxio.client.ReadType
 
getAlluxioStorageType() - Method in enum alluxio.client.WriteType
 
getAlluxioUri() - Method in class alluxio.master.file.meta.options.MountInfo
 
getAlluxioURIs(FileSystem, AlluxioURI) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets all the AlluxioURIs that match inputURI.
getAlluxioVersion() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional string alluxioVersion = 3;
getAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
optional string alluxioVersion = 3;
getAlluxioVersion() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
optional string alluxioVersion = 3;
getAlluxioVersionBytes() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional string alluxioVersion = 3;
getAlluxioVersionBytes() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
optional string alluxioVersion = 3;
getAlluxioVersionBytes() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
optional string alluxioVersion = 3;
getAllWorkerHealth() - Method in interface alluxio.client.job.JobMasterClient
Gets all worker health.
getAllWorkerHealth() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getAllWorkerHealth(GetAllWorkerHealthPRequest, StreamObserver<GetAllWorkerHealthPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Lists all worker health.
getAllWorkerHealth(GetAllWorkerHealthPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Lists all worker health.
getAllWorkerHealth(GetAllWorkerHealthPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Lists all worker health.
getAllWorkerHealth(GetAllWorkerHealthPRequest, StreamObserver<GetAllWorkerHealthPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Lists all worker health.
getAllWorkerHealth() - Method in class alluxio.master.job.JobMaster
 
getAllWorkerHealth(GetAllWorkerHealthPRequest, StreamObserver<GetAllWorkerHealthPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
GetAllWorkerHealthPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPOptions
GetAllWorkerHealthPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPOptions
GetAllWorkerHealthPOptionsOrBuilder - Interface in alluxio.grpc
 
GetAllWorkerHealthPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPRequest
GetAllWorkerHealthPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPRequest
GetAllWorkerHealthPRequestOrBuilder - Interface in alluxio.grpc
 
GetAllWorkerHealthPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPResponse
GetAllWorkerHealthPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetAllWorkerHealthPResponse
GetAllWorkerHealthPResponseOrBuilder - Interface in alluxio.grpc
 
getAllWorkers() - Method in class alluxio.client.file.FileSystemContext
Gets the worker information list.
getAlwaysEnableTLS() - Method in class alluxio.grpc.GrpcChannelBuilder
 
getAncestorInode() - Method in class alluxio.master.file.meta.LockedInodePath
Returns the closest ancestor of the target inode (last inode in the full path).
getAndClearTaskUpdates() - Method in class alluxio.worker.job.task.TaskExecutorManager
 
getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in interface alluxio.client.file.cache.CacheManager
Reads a part of a page if the queried page is found in the cache, stores the result in buffer.
getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in class alluxio.client.file.cache.LocalCacheManager
 
getAndLoad(PageId, int, int, ReadTargetBuffer, CacheContext, Supplier<byte[]>) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
getAnnotation(PropertyKey) - Method in class alluxio.conf.DeprecatedKeyChecker
Returns the annotation attached to the given property key.
getAppConfigurationEntry(String) - Method in class alluxio.security.login.LoginModuleConfiguration
 
getArgs() - Method in class alluxio.stress.job.StressBenchConfig
 
getArrayHeaderSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the fixed overhead of an array of any type or length in this JVM.
getAsync() - Method in class alluxio.grpc.CacheRequest.Builder
optional bool async = 6;
getAsync() - Method in class alluxio.grpc.CacheRequest
optional bool async = 6;
getAsync() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional bool async = 6;
getAsyncCacheMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getAsyncMode() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if this pool uses local first-in-first-out scheduling mode for forked tasks that are never joined.
getAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
getAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
getAsyncPersistOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
getAsyncPersistOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
getAsyncPersistOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
getAsyncPersistOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
getAsyncPersistOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
getAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
getAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
getAsyncPersistRequest() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
getAsyncPersistRequestBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
getAsyncPersistRequestOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
getAsyncPersistRequestOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
getAsyncPersistRequestOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
getAsyncWriteThreads() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
getAttachDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getAttemptCount() - Method in class alluxio.retry.CountingRetry
 
getAttemptCount() - Method in interface alluxio.retry.RetryPolicy
How many retries have been performed.
getAttemptCount() - Method in class alluxio.retry.SleepingRetry
 
getAttemptCount() - Method in class alluxio.retry.TimeBoundedRetry
 
getAttemptCount() - Method in class alluxio.retry.TimeoutRetry
 
getattr(String, FileStat) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
getattr(String, FileStat) - Method in class alluxio.fuse.StackFS
 
getattr(String, FileStat) - Method in interface alluxio.jnifuse.FuseFileSystem
 
getattrCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
getAuditLogEntriesSize() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
Gets the size of audit log entries.
getAuthenticatedUserInfo() - Method in class alluxio.security.authentication.plain.SaslServerHandlerPlain
 
getAuthenticatedUserInfo() - Method in interface alluxio.security.authentication.SaslServerHandler
Used to get the authenticated user info after the completed session.
getAuthenticateMethod() - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
 
getAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
getAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
getAuthenticationScheme() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
getAuthenticationServer() - Method in class alluxio.grpc.GrpcServer
 
getAuthInfo() - Method in class alluxio.s3.signature.AwsSignatureProcessor
Convert SignatureInfo to AwsAuthInfo.
getAuthMethod(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the connection authentication method from the ThreadLocal variable.
getAuthMethod() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
getAuthority() - Method in class alluxio.AlluxioURI
 
getAuthority() - Method in class alluxio.uri.StandardURI
 
getAuthority() - Method in interface alluxio.uri.URI
 
getAuthorizationID() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
getAuthorizedUserName() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
getAuthPolicy() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
Get the file system authority policy.
getAuthType() - Method in class alluxio.grpc.GrpcChannelBuilder
 
getAvailable() - Method in class alluxio.extensions.ExtensionFactoryRegistry
Returns a read-only view of the available base factories.
getAvailableBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getAvailableBytes() - Method in class alluxio.wire.JournalDiskInfo
 
getAvailableBytes() - Method in interface alluxio.worker.block.meta.StorageDir
Gets the total available capacity of this StorageDir in bytes.
getAvailableBytes() - Method in interface alluxio.worker.block.meta.StorageTier
 
getAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional double avg_col_len = 2;
getAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional double avg_col_len = 2;
getAvgColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional double avg_col_len = 2;
getAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional double avg_col_len = 2;
getAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
optional double avg_col_len = 2;
getAvgColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional double avg_col_len = 2;
getAwsAccessId() - Method in class alluxio.s3.signature.SignatureInfo
 
getAwsRegion() - Method in class alluxio.s3.signature.AwsCredential
 
getAwsRequest() - Method in class alluxio.s3.signature.AwsCredential
 
getAwsService() - Method in class alluxio.s3.signature.AwsCredential
 
getBackupError() - Method in class alluxio.grpc.BackupPStatus.Builder
optional bytes backupError = 6;
getBackupError() - Method in class alluxio.grpc.BackupPStatus
optional bytes backupError = 6;
getBackupError() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional bytes backupError = 6;
getBackupHost() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupHost = 3;
getBackupHost() - Method in class alluxio.grpc.BackupPStatus
optional string backupHost = 3;
getBackupHost() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupHost = 3;
getBackupHostBytes() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupHost = 3;
getBackupHostBytes() - Method in class alluxio.grpc.BackupPStatus
optional string backupHost = 3;
getBackupHostBytes() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupHost = 3;
getBackupId() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupId = 1;
getBackupId() - Method in class alluxio.grpc.BackupPStatus
optional string backupId = 1;
getBackupId() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupId = 1;
getBackupId() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
optional string backupId = 1;
getBackupId() - Method in class alluxio.grpc.BackupStatusPRequest
optional string backupId = 1;
getBackupId() - Method in interface alluxio.grpc.BackupStatusPRequestOrBuilder
optional string backupId = 1;
getBackupId() - Method in class alluxio.master.backup.BackupRequestMessage
 
getBackupId() - Method in class alluxio.wire.BackupStatus
 
getBackupIdBytes() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupId = 1;
getBackupIdBytes() - Method in class alluxio.grpc.BackupPStatus
optional string backupId = 1;
getBackupIdBytes() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupId = 1;
getBackupIdBytes() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
optional string backupId = 1;
getBackupIdBytes() - Method in class alluxio.grpc.BackupStatusPRequest
optional string backupId = 1;
getBackupIdBytes() - Method in interface alluxio.grpc.BackupStatusPRequestOrBuilder
optional string backupId = 1;
getBackupManager() - Method in class alluxio.master.CoreMasterContext
 
getBackupMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getBackupRequest() - Method in class alluxio.master.backup.BackupRequestMessage
 
getBackupState() - Method in class alluxio.grpc.BackupPStatus.Builder
optional .alluxio.grpc.meta.BackupState backupState = 2;
getBackupState() - Method in class alluxio.grpc.BackupPStatus
optional .alluxio.grpc.meta.BackupState backupState = 2;
getBackupState() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional .alluxio.grpc.meta.BackupState backupState = 2;
getBackupStatus(UUID) - Method in interface alluxio.client.meta.MetaMasterClient
Queries the status of a backup.
getBackupStatus(UUID) - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
getBackupStatus(BackupStatusPRequest, StreamObserver<BackupPStatus>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
Returns status of the latest backup.
getBackupStatus(BackupStatusPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
Returns status of the latest backup.
getBackupStatus(BackupStatusPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
Returns status of the latest backup.
getBackupStatus(BackupStatusPRequest, StreamObserver<BackupPStatus>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
Returns status of the latest backup.
getBackupStatus() - Method in class alluxio.master.backup.BackupHeartbeatMessage
 
getBackupStatus(BackupStatusPRequest) - Method in class alluxio.master.backup.BackupLeaderRole
 
getBackupStatus(BackupStatusPRequest) - Method in interface alluxio.master.backup.BackupOps
Used to query the status of a backup.
getBackupStatus(BackupStatusPRequest) - Method in class alluxio.master.backup.BackupWorkerRole
 
getBackupStatus(BackupStatusPRequest) - Method in class alluxio.master.meta.DefaultMetaMaster
 
getBackupStatus(BackupStatusPRequest, StreamObserver<BackupPStatus>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
getBackupUri() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupUri = 4;
getBackupUri() - Method in class alluxio.grpc.BackupPStatus
optional string backupUri = 4;
getBackupUri() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupUri = 4;
getBackupUri() - Method in class alluxio.wire.BackupStatus
 
getBackupUriBytes() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupUri = 4;
getBackupUriBytes() - Method in class alluxio.grpc.BackupPStatus
optional string backupUri = 4;
getBackupUriBytes() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupUri = 4;
getBackupWorkerHostname() - Method in class alluxio.master.backup.BackupHandshakeMessage
 
getBandwidth() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional int64 bandwidth = 1;
getBandwidth() - Method in class alluxio.grpc.CopyJobPOptions
optional int64 bandwidth = 1;
getBandwidth() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional int64 bandwidth = 1;
getBandwidth() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional int64 bandwidth = 1;
getBandwidth() - Method in class alluxio.grpc.LoadJobPOptions
optional int64 bandwidth = 1;
getBandwidth() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional int64 bandwidth = 1;
getBandwidth() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional int64 bandwidth = 1;
getBandwidth() - Method in class alluxio.grpc.MoveJobPOptions
optional int64 bandwidth = 1;
getBandwidth() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional int64 bandwidth = 1;
getBandwidth() - Method in class alluxio.grpc.UfsReadOptions.Builder
optional int64 bandwidth = 3;
getBandwidth() - Method in class alluxio.grpc.UfsReadOptions
optional int64 bandwidth = 3;
getBandwidth() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
optional int64 bandwidth = 3;
getBandwidth() - Method in class alluxio.master.job.CopyJob
Get bandwidth.
getBandwidth() - Method in class alluxio.master.job.DoraLoadJob
Get bandwidth.
getBandwidth() - Method in class alluxio.master.job.LoadJob
Get bandwidth.
getBandwidth() - Method in class alluxio.master.job.MoveJob
Get bandwidth.
getBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 bandwidth = 4;
getBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional int64 bandwidth = 4;
getBandwidth() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional int64 bandwidth = 4;
getBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 bandwidth = 3;
getBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional int64 bandwidth = 3;
getBandwidth() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional int64 bandwidth = 3;
getBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 bandwidth = 4;
getBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional int64 bandwidth = 4;
getBandwidth() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional int64 bandwidth = 4;
getBaseLayout() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
getBaseLayout() - Method in class alluxio.grpc.table.Partition
optional .alluxio.grpc.table.Layout base_layout = 2;
getBaseLayout() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional .alluxio.grpc.table.Layout base_layout = 2;
getBaseLayoutBuilder() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
getBaseLayoutOrBuilder() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
getBaseLayoutOrBuilder() - Method in class alluxio.grpc.table.Partition
optional .alluxio.grpc.table.Layout base_layout = 2;
getBaseLayoutOrBuilder() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional .alluxio.grpc.table.Layout base_layout = 2;
getBaseName(String) - Static method in class alluxio.metrics.Metric
Gets the simple name without the tags.
getBaseParameters() - Method in class alluxio.stress.client.ClientIOSummary
 
getBaseParameters() - Method in class alluxio.stress.client.ClientIOTaskResult
 
getBaseParameters() - Method in interface alluxio.stress.TaskResult
 
getBaseParameters() - Method in class alluxio.stress.worker.IOTaskResult
 
getBaseParameters() - Method in class alluxio.stress.worker.IOTaskSummary
 
getBaseParameters() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getBatchCount() - Method in class alluxio.worker.block.BlockMapIterator
Gets the number of batches.
getBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Batch size for partial listings.
getBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions
Batch size for partial listings.
getBatchSize() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Batch size for partial listings.
getBatchSize() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
 
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Gets the batch size.
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
 
getBenchDescription() - Method in class alluxio.stress.cli.Benchmark
Get the description of the bench.
getBenchDescription() - Method in class alluxio.stress.cli.client.StressClientIOBench
 
getBenchDescription() - Method in class alluxio.stress.cli.UfsIOBench
 
getBenchDescription() - Method in class alluxio.stress.cli.worker.StressWorkerBench
 
getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBinaryStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
getBindAddress(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the bind hostname for a given service.
getBindAddress() - Method in interface alluxio.worker.DataServer
Gets the actual bind socket address.
getBindAddress() - Method in class alluxio.worker.grpc.GrpcDataServer
 
getBindAddress() - Method in class alluxio.worker.netty.NettyDataServer
 
getBindHost(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the InetSocketAddress bind address on a given service.
getBindHost() - Method in class alluxio.web.WebServer
Gets the actual bind hostname.
getBindHostKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the key of bind hostname.
getBindHostKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of bind hostname.
getBindPort() - Method in class alluxio.grpc.GrpcServer
 
getBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.Bits bits = 1;
getBits() - Method in class alluxio.grpc.CheckAccessPOptions
optional .alluxio.grpc.Bits bits = 1;
getBits() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
optional .alluxio.grpc.Bits bits = 1;
getBitsPerClock() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
getBitsPerScope() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
getBitsPerSize() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
getBitsPerTag() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
getBitsPerTag() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
 
getBitsPerTag() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
getBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional string bit_vectors = 4;
getBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional string bit_vectors = 4;
getBitVectors() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional string bit_vectors = 4;
getBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional string bit_vectors = 4;
getBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional string bit_vectors = 4;
getBitVectors() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional string bit_vectors = 4;
getBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData
optional string bit_vectors = 5;
getBitVectors() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional string bit_vectors = 5;
getBitVectors() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional string bit_vectors = 5;
getBitVectors() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData
optional string bit_vectors = 5;
getBitVectors() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData
optional string bit_vectors = 5;
getBitVectors() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional string bit_vectors = 4;
getBitVectorsBytes() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional string bit_vectors = 4;
getBitVectorsBytes() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional string bit_vectors = 4;
getBitVectorsBytes() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional string bit_vectors = 4;
getBitVectorsBytes() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional string bit_vectors = 4;
getBitVectorsBytes() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional string bit_vectors = 4;
getBitVectorsBytes() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.DateColumnStatsData
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.LongColumnStatsData
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in class alluxio.grpc.table.StringColumnStatsData
optional string bit_vectors = 5;
getBitVectorsBytes() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional string bit_vectors = 5;
getBlock() - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
getBlock() - Method in class alluxio.grpc.BlockStatus
required .alluxio.grpc.block.Block block = 1;
getBlock() - Method in interface alluxio.grpc.BlockStatusOrBuilder
required .alluxio.grpc.block.Block block = 1;
getBlock(long) - Method in interface alluxio.master.metastore.BlockMetaStore
 
getBlock(long) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
getBlock(long) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
getBlockBuilder() - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
getBlockChangeCount() - Method in class alluxio.worker.block.BlockHeartbeatReport
 
getBlockClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getBlockContainerId() - Method in class alluxio.master.file.meta.InodeFile
 
getBlockContainerId() - Method in interface alluxio.master.file.meta.InodeFileView
 
getBlockContainerId() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockContainerIdGeneratorOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
getBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
getBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
getBlockCount() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
getBlockCount() - Method in class alluxio.master.block.meta.MasterWorkerInfo
Return the block count of this worker.
getBlockCount() - Method in class alluxio.util.webui.NodeInfo
Gets worker block count.
getBlockCount() - Method in class alluxio.wire.WorkerInfo
 
getBlockCount() - Method in class alluxio.wire.WorkerWebUIOverview
Gets block count.
getBlockDeletionContext() - Method in class alluxio.master.file.RpcContext
 
getBlockHeartbeatMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getBlockId() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.AsyncCacheRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.Block.Builder
required int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.Block
required int64 block_id = 1;
getBlockId(int) - Method in class alluxio.grpc.BlockIdList.Builder
repeated int64 blockId = 1;
getBlockId(int) - Method in class alluxio.grpc.BlockIdList
repeated int64 blockId = 1;
getBlockId(int) - Method in interface alluxio.grpc.BlockIdListOrBuilder
repeated int64 blockId = 1;
getBlockId() - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 blockId = 1;
getBlockId() - Method in class alluxio.grpc.BlockInfo
optional int64 blockId = 1;
getBlockId() - Method in interface alluxio.grpc.BlockInfoOrBuilder
optional int64 blockId = 1;
getBlockId() - Method in interface alluxio.grpc.BlockOrBuilder
required int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.CacheRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the block being committed
getBlockId() - Method in class alluxio.grpc.CommitBlockPRequest
the id of the block being committed
getBlockId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the id of the block being committed
getBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
the id of the block
getBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest
the id of the block
getBlockId() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
the id of the block
getBlockId() - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.MoveBlockRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.ReadRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.grpc.RemoveBlockRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.grpc.RemoveBlockRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.job.plan.replicate.MoveConfig
 
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCloseRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
optional int64 block_id = 1;
getBlockId() - Method in interface alluxio.proto.journal.Block.DeleteBlockEntryOrBuilder
optional int64 block_id = 1;
getBlockId() - Method in class alluxio.wire.BlockInfo
 
getBlockId() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getBlockId() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getBlockIdByIndex(int) - Method in class alluxio.master.file.meta.InodeFile
 
getBlockIdByIndex(int) - Method in interface alluxio.master.file.meta.InodeFileView
Gets the block id for a given index.
getBlockIdByIndex(int) - Method in class alluxio.master.file.meta.MutableInodeFile
 
getBlockIdCount() - Method in class alluxio.grpc.BlockIdList.Builder
repeated int64 blockId = 1;
getBlockIdCount() - Method in class alluxio.grpc.BlockIdList
repeated int64 blockId = 1;
getBlockIdCount() - Method in interface alluxio.grpc.BlockIdListOrBuilder
repeated int64 blockId = 1;
getBlockIdList() - Method in class alluxio.grpc.BlockIdList.Builder
repeated int64 blockId = 1;
getBlockIdList() - Method in class alluxio.grpc.BlockIdList
repeated int64 blockId = 1;
getBlockIdList() - Method in interface alluxio.grpc.BlockIdListOrBuilder
repeated int64 blockId = 1;
getBlockIds() - Method in class alluxio.client.file.URIStatus
 
getBlockIds(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated int64 blockIds = 13;
getBlockIds(int) - Method in class alluxio.grpc.FileInfo
repeated int64 blockIds = 13;
getBlockIds(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated int64 blockIds = 13;
getBlockIds(int) - Method in class alluxio.grpc.PersistFile.Builder
repeated int64 blockIds = 2;
getBlockIds(int) - Method in class alluxio.grpc.PersistFile
repeated int64 blockIds = 2;
getBlockIds(int) - Method in interface alluxio.grpc.PersistFileOrBuilder
repeated int64 blockIds = 2;
getBlockIds() - Method in class alluxio.master.file.meta.InodeFile
 
getBlockIds() - Method in interface alluxio.master.file.meta.InodeFileView
 
getBlockIds() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getBlockIds(int) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
getBlockIds(int) - Method in class alluxio.proto.journal.File.CompleteFileEntry
repeated int64 block_ids = 1;
getBlockIds(int) - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
repeated int64 block_ids = 1;
getBlockIds() - Method in class alluxio.util.webui.UIFileInfo
Gets BlockId List.
getBlockIds() - Method in class alluxio.wire.FileInfo
 
getBlockIds() - Method in class alluxio.wire.PersistFile
 
getBlockIds() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the list of block ids in this dir.
getBlockIdsCount() - Method in class alluxio.grpc.FileInfo.Builder
repeated int64 blockIds = 13;
getBlockIdsCount() - Method in class alluxio.grpc.FileInfo
repeated int64 blockIds = 13;
getBlockIdsCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated int64 blockIds = 13;
getBlockIdsCount() - Method in class alluxio.grpc.PersistFile.Builder
repeated int64 blockIds = 2;
getBlockIdsCount() - Method in class alluxio.grpc.PersistFile
repeated int64 blockIds = 2;
getBlockIdsCount() - Method in interface alluxio.grpc.PersistFileOrBuilder
repeated int64 blockIds = 2;
getBlockIdsCount() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
getBlockIdsCount() - Method in class alluxio.proto.journal.File.CompleteFileEntry
repeated int64 block_ids = 1;
getBlockIdsCount() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
repeated int64 block_ids = 1;
getBlockIdsList() - Method in class alluxio.grpc.FileInfo.Builder
repeated int64 blockIds = 13;
getBlockIdsList() - Method in class alluxio.grpc.FileInfo
repeated int64 blockIds = 13;
getBlockIdsList() - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated int64 blockIds = 13;
getBlockIdsList() - Method in class alluxio.grpc.PersistFile.Builder
repeated int64 blockIds = 2;
getBlockIdsList() - Method in class alluxio.grpc.PersistFile
repeated int64 blockIds = 2;
getBlockIdsList() - Method in interface alluxio.grpc.PersistFileOrBuilder
repeated int64 blockIds = 2;
getBlockIdsList() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
getBlockIdsList() - Method in class alluxio.proto.journal.File.CompleteFileEntry
repeated int64 block_ids = 1;
getBlockIdsList() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
repeated int64 block_ids = 1;
getBlockInfo(long) - Method in interface alluxio.client.block.BlockMasterClient
Returns the BlockInfo for a block id.
getBlockInfo(long) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getBlockInfo(long) - Method in class alluxio.client.file.options.InStreamOptions
 
getBlockInfo(long) - Method in class alluxio.client.file.URIStatus
 
getBlockInfo(GetBlockInfoPRequest, StreamObserver<GetBlockInfoPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns the block information for the given block id.
getBlockInfo(GetBlockInfoPRequest) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns the block information for the given block id.
getBlockInfo(GetBlockInfoPRequest) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns the block information for the given block id.
getBlockInfo(GetBlockInfoPRequest, StreamObserver<GetBlockInfoPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns the block information for the given block id.
getBlockInfo() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfo() - Method in class alluxio.grpc.FileBlockInfo
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfo() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfo() - Method in interface alluxio.grpc.GetBlockInfoPResponseOrBuilder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfo(long) - Method in interface alluxio.master.block.BlockMaster
 
getBlockInfo(GetBlockInfoPRequest, StreamObserver<GetBlockInfoPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getBlockInfo(long) - Method in class alluxio.master.block.DefaultBlockMaster
 
getBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
getBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
getBlockInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
getBlockInfo() - Method in class alluxio.wire.BlockLocationInfo
 
getBlockInfo() - Method in class alluxio.wire.FileBlockInfo
 
getBlockInfoBuilder() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoBuilder() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
getBlockInfoList(List<Long>) - Method in interface alluxio.master.block.BlockMaster
Retrieves information for the given list of block ids.
getBlockInfoList(List<Long>) - Method in class alluxio.master.block.DefaultBlockMaster
 
getBlockInfoOrBuilder() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoOrBuilder() - Method in class alluxio.grpc.FileBlockInfo
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoOrBuilder() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPResponse
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoOrBuilder() - Method in interface alluxio.grpc.GetBlockInfoPResponseOrBuilder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
getBlockInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
getBlockInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
getBlockInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
GetBlockInfoPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockInfoPOptions
GetBlockInfoPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockInfoPOptions
GetBlockInfoPOptionsOrBuilder - Interface in alluxio.grpc
 
GetBlockInfoPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockInfoPRequest
GetBlockInfoPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockInfoPRequest
GetBlockInfoPRequestOrBuilder - Interface in alluxio.grpc
 
GetBlockInfoPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockInfoPResponse
GetBlockInfoPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockInfoPResponse
GetBlockInfoPResponseOrBuilder - Interface in alluxio.grpc
 
getBlockLength() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets block length.
getBlockList() - Method in interface alluxio.worker.block.BlockStoreMeta
Note: This method is only available when users initialize the blockStoreMeta with full block meta requirement.
getBlockListByStorageLocation() - Method in interface alluxio.worker.block.BlockStoreMeta
Note: This method is only available when users initialize the blockStoreMeta with full block meta requirement.
getBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
getBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional .alluxio.grpc.BlockLocation block_location = 3;
getBlockLocation() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional .alluxio.grpc.BlockLocation block_location = 3;
getBlockLocation() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getBlockLocation() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getBlockLocationBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
getBlockLocationOrBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
getBlockLocationOrBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional .alluxio.grpc.BlockLocation block_location = 3;
getBlockLocationOrBuilder() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional .alluxio.grpc.BlockLocation block_location = 3;
getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.DelegatingFileSystem
 
getBlockLocations(URIStatus) - Method in class alluxio.client.file.DelegatingFileSystem
 
getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
Get the location information of the specified file.
getBlockLocations(URIStatus) - Method in class alluxio.client.file.DoraCacheFileSystem
Get the location information of the specified file.
getBlockLocations(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Builds a list of BlockLocationInfo for the given file.
getBlockLocations(URIStatus) - Method in interface alluxio.client.file.FileSystem
Builds a list of BlockLocationInfo for the given file.
getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
getBlockLocations(URIStatus) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
getBlockLocations(AlluxioURI) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getBlockLocations(URIStatus) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getBlockMasterClient() - Method in class alluxio.multi.process.Clients
 
getBlockMasterInfo(Set<BlockMasterInfo.BlockMasterInfoField>) - Method in interface alluxio.client.block.BlockMasterClient
 
getBlockMasterInfo(Set<BlockMasterInfo.BlockMasterInfoField>) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getBlockMasterInfo(GetBlockMasterInfoPOptions, StreamObserver<GetBlockMasterInfoPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns block master information.
getBlockMasterInfo(GetBlockMasterInfoPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns block master information.
getBlockMasterInfo(GetBlockMasterInfoPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns block master information.
getBlockMasterInfo(GetBlockMasterInfoPOptions, StreamObserver<GetBlockMasterInfoPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns block master information.
getBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
getBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
getBlockMasterInfo() - Method in interface alluxio.grpc.GetBlockMasterInfoPResponseOrBuilder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
getBlockMasterInfo(GetBlockMasterInfoPOptions, StreamObserver<GetBlockMasterInfoPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getBlockMasterInfoBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
getBlockMasterInfoOrBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
getBlockMasterInfoOrBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
getBlockMasterInfoOrBuilder() - Method in interface alluxio.grpc.GetBlockMasterInfoPResponseOrBuilder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
GetBlockMasterInfoPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPOptions
GetBlockMasterInfoPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPOptions
GetBlockMasterInfoPOptionsOrBuilder - Interface in alluxio.grpc
 
GetBlockMasterInfoPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPResponse
GetBlockMasterInfoPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetBlockMasterInfoPResponse
GetBlockMasterInfoPResponseOrBuilder - Interface in alluxio.grpc
 
getBlockMeta(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of a specific block from local storage.
getBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Gets the BlockMeta from this storage dir by its block id.
getBlockMetaStore() - Method in class alluxio.master.block.DefaultBlockMaster
 
getBlockOrBuilder() - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
getBlockOrBuilder() - Method in class alluxio.grpc.BlockStatus
required .alluxio.grpc.block.Block block = 1;
getBlockOrBuilder() - Method in interface alluxio.grpc.BlockStatusOrBuilder
required .alluxio.grpc.block.Block block = 1;
getBlockReader() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getBlockReader() - Method in class alluxio.worker.netty.BlockReadRequestContext
 
getBlockReplicaCount() - Method in interface alluxio.master.block.BlockMaster
 
getBlockReplicaCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getBlocks(int) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocks(int) - Method in class alluxio.grpc.LoadRequest
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocks(int) - Method in interface alluxio.grpc.LoadRequestOrBuilder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocks() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getBlocks() - Method in class alluxio.master.job.LoadJob.LoadTask
 
getBlocks(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
getBlocks(int) - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated int64 blocks = 12;
getBlocks(int) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated int64 blocks = 12;
getBlocks(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated int64 blocks = 16;
getBlocks(int) - Method in class alluxio.proto.meta.InodeMeta.Inode
repeated int64 blocks = 16;
getBlocks(int) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
repeated int64 blocks = 16;
getBlocks() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the list of blocks stored in this dir.
getBlocksBuilder(int) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksBuilderList() - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksCount() - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksCount() - Method in class alluxio.grpc.LoadRequest
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksCount() - Method in interface alluxio.grpc.LoadRequestOrBuilder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksCount() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
getBlocksCount() - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated int64 blocks = 12;
getBlocksCount() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated int64 blocks = 12;
getBlocksCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated int64 blocks = 16;
getBlocksCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
repeated int64 blocks = 16;
getBlocksCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
repeated int64 blocks = 16;
getBlockSize() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 block_size = 3;
getBlockSize() - Method in class alluxio.grpc.UfsFileStatus
optional int64 block_size = 3;
getBlockSize() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
optional int64 block_size = 3;
getBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The block size.
getBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
The block size.
getBlockSize() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
The block size.
getBlockSize() - Method in class alluxio.underfs.UfsFileStatus
 
getBlockSize() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getBlockSize() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getBlockSizeByte(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getBlockSizeByte(String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
 
getBlockSizeByte(String) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
 
getBlockSizeByte(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
getBlockSizeByte(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getBlockSizeByte(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getBlockSizeByte(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets the block size in bytes.
getBlockSizeByte(String) - Method in interface alluxio.underfs.UnderFileSystem
Deprecated.
getBlockSizeByte(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getBlockSizeByte(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getBlockSizeBytes() - Method in class alluxio.client.file.options.OutStreamOptions
 
getBlockSizeBytes() - Method in class alluxio.client.file.URIStatus
 
getBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 blockSizeBytes = 1;
getBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions
optional int64 blockSizeBytes = 1;
getBlockSizeBytes() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int64 blockSizeBytes = 1;
getBlockSizeBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 blockSizeBytes = 6;
getBlockSizeBytes() - Method in class alluxio.grpc.FileInfo
optional int64 blockSizeBytes = 6;
getBlockSizeBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 blockSizeBytes = 6;
getBlockSizeBytes() - Method in class alluxio.master.file.meta.InodeFile
 
getBlockSizeBytes() - Method in interface alluxio.master.file.meta.InodeFileView
 
getBlockSizeBytes() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 block_size_bytes = 8;
getBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 block_size_bytes = 8;
getBlockSizeBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 block_size_bytes = 8;
getBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 block_size_bytes = 2;
getBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 block_size_bytes = 2;
getBlockSizeBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 block_size_bytes = 2;
getBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
file only
getBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
file only
getBlockSizeBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
file only
getBlockSizeBytes() - Method in class alluxio.util.webui.UIFileInfo
Gets block size bytes.
getBlockSizeBytes() - Method in class alluxio.wire.FileInfo
 
getBlockSizeBytes() - Method in class alluxio.wire.MasterWebUIBrowse
Gets block size bytes.
getBlockSizeBytes() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets block size bytes.
getBlocksList() - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksList() - Method in class alluxio.grpc.LoadRequest
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksList() - Method in interface alluxio.grpc.LoadRequestOrBuilder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksList() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
getBlocksList() - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated int64 blocks = 12;
getBlocksList() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated int64 blocks = 12;
getBlocksList() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated int64 blocks = 16;
getBlocksList() - Method in class alluxio.proto.meta.InodeMeta.Inode
repeated int64 blocks = 16;
getBlocksList() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
repeated int64 blocks = 16;
getBlocksOnTier() - Method in class alluxio.util.webui.UIFileInfo
Gets blocks on tier.
getBlocksOrBuilder(int) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksOrBuilder(int) - Method in class alluxio.grpc.LoadRequest
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksOrBuilder(int) - Method in interface alluxio.grpc.LoadRequestOrBuilder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksOrBuilderList() - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksOrBuilderList() - Method in class alluxio.grpc.LoadRequest
repeated .alluxio.grpc.block.Block blocks = 1;
getBlocksOrBuilderList() - Method in interface alluxio.grpc.LoadRequestOrBuilder
repeated .alluxio.grpc.block.Block blocks = 1;
getBlockStatus(int) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatus(int) - Method in class alluxio.grpc.LoadResponse
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatus(int) - Method in interface alluxio.grpc.LoadResponseOrBuilder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusBuilder(int) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusBuilderList() - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusCount() - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusCount() - Method in class alluxio.grpc.LoadResponse
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusCount() - Method in interface alluxio.grpc.LoadResponseOrBuilder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusList() - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusList() - Method in class alluxio.grpc.LoadResponse
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusList() - Method in interface alluxio.grpc.LoadResponseOrBuilder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusOrBuilder(int) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusOrBuilder(int) - Method in class alluxio.grpc.LoadResponse
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusOrBuilder(int) - Method in interface alluxio.grpc.LoadResponseOrBuilder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusOrBuilderList() - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusOrBuilderList() - Method in class alluxio.grpc.LoadResponse
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStatusOrBuilderList() - Method in interface alluxio.grpc.LoadResponseOrBuilder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
getBlockStore() - Method in interface alluxio.worker.block.BlockWorker
 
getBlockStoreFactory() - Method in class alluxio.master.CoreMasterContext
 
getBlockStoreFactory(String) - Static method in class alluxio.master.MasterUtils
 
getBlockStoreMeta() - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of the entire store in a snapshot.
getBlockStoreMetaFull() - Method in interface alluxio.worker.block.BlockStore
Similar as BlockStore.getBlockStoreMeta() except that this includes more information about the block store (e.g.
getBlockWorkerClientPoolMap() - Method in class alluxio.client.file.FileSystemContext
 
getBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a writer to write data to a temp block.
getBlockWriter() - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
getBoolArg(CommandLine, Option, boolean) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the value of an option from the command line.
getBoolean(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the boolean representation of the value for the given key.
getBoolean(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the boolean representation of the value for the given key.
getBoolean(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getBoolean(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
getBooleanType() - Method in class alluxio.grpc.table.Value.Builder
bool boolean_type = 4;
getBooleanType() - Method in class alluxio.grpc.table.Value
bool boolean_type = 4;
getBooleanType() - Method in interface alluxio.grpc.table.ValueOrBuilder
bool boolean_type = 4;
getBucket() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getBucket() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
getBucket() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
 
getBucket() - Method in class alluxio.proxy.s3.ListPartsResult
 
getBucket() - Method in class alluxio.proxy.s3.S3Handler
Get the bucket name of this request.
getBucket(String, String, String, String, String, Integer, Integer, String, String, String, String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Gets a bucket and lists all the objects or bucket tags in it.
getBucket() - Method in class alluxio.worker.s3.S3NettyHandler
Get the bucket name of this request.
getBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
optional int64 bucket_count = 2;
getBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
optional int64 bucket_count = 2;
getBucketCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
optional int64 bucket_count = 2;
getBucketedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
getBucketedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated string bucketed_by = 1;
getBucketedBy(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated string bucketed_by = 1;
getBucketedByBytes(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
getBucketedByBytes(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated string bucketed_by = 1;
getBucketedByBytes(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated string bucketed_by = 1;
getBucketedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
getBucketedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated string bucketed_by = 1;
getBucketedByCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated string bucketed_by = 1;
getBucketedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
getBucketedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated string bucketed_by = 1;
getBucketedByList() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated string bucketed_by = 1;
getBucketIndex() - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
 
getBucketName() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getBucketName(AlluxioURI) - Static method in class alluxio.util.UnderFileSystemUtils
 
getBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
getBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
getBucketProperty() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
getBucketPropertyBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
getBucketPropertyOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
getBucketPropertyOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
getBucketPropertyOrBuilder() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
getBuckets() - Method in class alluxio.s3.ListAllMyBucketsResult
 
getBuffer() - Method in class alluxio.grpc.DataMessage
 
getBuffer() - Method in class alluxio.jnifuse.struct.FileStat
 
getBufferFromStream(InputStream) - Static method in class alluxio.grpc.GrpcSerializationUtils
Gets a buffer directly from a gRPC input stream.
getBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
getBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions
the worker version to display in info pages (useful for rolling upgrades)
getBuildVersion() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
the worker version to display in info pages (useful for rolling upgrades)
getBuildVersion() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
getBuildVersion() - Method in class alluxio.grpc.WorkerInfo
optional .alluxio.grpc.BuildVersion buildVersion = 10;
getBuildVersion() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
getBuildVersion() - Method in class alluxio.master.block.meta.MasterWorkerInfo
Get the build version of the worker.
getBuildVersionBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
getBuildVersionBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
getBuildVersionOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
getBuildVersionOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions
the worker version to display in info pages (useful for rolling upgrades)
getBuildVersionOrBuilder() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
the worker version to display in info pages (useful for rolling upgrades)
getBuildVersionOrBuilder() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
getBuildVersionOrBuilder() - Method in class alluxio.grpc.WorkerInfo
optional .alluxio.grpc.BuildVersion buildVersion = 10;
getBuildVersionOrBuilder() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
getByField(V) - Method in interface alluxio.collections.FieldIndex
Gets a subset of objects with the specified field value.
getByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Gets a subset of objects with the specified field value.
getByField(V) - Method in class alluxio.collections.NonUniqueFieldIndex
 
getByField(V) - Method in class alluxio.collections.UniqueFieldIndex
 
getBypassDelegation() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool bypassDelegation = 4;
getBypassDelegation() - Method in class alluxio.grpc.BackupPOptions
optional bool bypassDelegation = 4;
getBypassDelegation() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool bypassDelegation = 4;
getByteBufFromReadableBuffer(ReadableBuffer) - Static method in class alluxio.grpc.GrpcSerializationUtils
Gets a Netty buffer directly from a gRPC ReadableBuffer.
getBytes(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the bytes of the value for the given key.
getBytes(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the bytes of the value for the given key.
getBytes(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
optional int64 bytes = 1;
getBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse
optional int64 bytes = 1;
getBytes() - Method in interface alluxio.grpc.GetCapacityBytesPResponseOrBuilder
optional int64 bytes = 1;
getBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
optional int64 bytes = 1;
getBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse
optional int64 bytes = 1;
getBytes() - Method in interface alluxio.grpc.GetUsedBytesPResponseOrBuilder
optional int64 bytes = 1;
getBytes(long, byte[]) - Method in class alluxio.inode.RocksBenchBase
 
getBytes(long) - Method in class alluxio.inode.RocksBenchBase
 
getBytes(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getBytesRead() - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Gets the number of bytes that has been received and written into the output channel.
getBytesRead() - Method in exception alluxio.client.file.dora.netty.PartialReadException
 
getBytesReserved() - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
getBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int64 bytes_skipped = 4;
getBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse
optional int64 bytes_skipped = 4;
getBytesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
optional int64 bytes_skipped = 4;
getBytesWanted() - Method in exception alluxio.client.file.dora.netty.PartialReadException
 
getBytesWritten() - Method in class alluxio.client.file.FileOutStream
 
getBytesWritten() - Method in class alluxio.client.file.ufs.UfsFileOutStream
 
getCacheable() - Method in class alluxio.grpc.FileInfo.Builder
optional bool cacheable = 11;
getCacheable() - Method in class alluxio.grpc.FileInfo
optional bool cacheable = 11;
getCacheable() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool cacheable = 11;
getCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool cacheable = 11;
getCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool cacheable = 11;
getCacheable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool cacheable = 11;
getCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool cacheable = 5;
getCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional bool cacheable = 5;
getCacheable() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional bool cacheable = 5;
getCacheContext() - Method in class alluxio.client.file.URIStatus
 
getCached(long, String, String) - Static method in class alluxio.util.proto.BlockLocationUtils
Get a shared grpc block location object.
getCached(Block.BlockLocation) - Static method in class alluxio.util.proto.BlockLocationUtils
Get a shared grpc block location object.
getCachedBlockLocationSize() - Static method in class alluxio.util.proto.BlockLocationUtils
Gets the cached block location size.
getCachedBytes() - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
getCachedGaugeTimeoutMillis() - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
getCachedPageIdsByFileId(String, long) - Method in interface alluxio.client.file.cache.CacheManager
Get page ids by the given file id.
getCachedPageIdsByFileId(String, long) - Method in class alluxio.client.file.cache.LocalCacheManager
 
getCachedPageIdsByFileId(String, long) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
getCachedPercentage(FileInfo, String) - Method in class alluxio.worker.dora.PagedDoraWorker
 
getCachedWorkers() - Method in class alluxio.client.file.FileSystemContext
Gets the cached live worker information list.
getCachedWorkers(FileSystemContext.GetWorkerListType) - Method in class alluxio.client.file.FileSystemContext
Gets the cached worker information list.
getCacheEnabled() - Method in class alluxio.client.file.cache.context.CachePerThreadContext
 
getCacheEvictorOptions() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
getCacheHit() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache hit.
getCacheIdentifier() - Method in class alluxio.client.file.CacheContext
Returns an string as a hint from computation to indicate the file.
getCacheMap() - Method in class alluxio.master.metastore.caching.Cache
 
getCacheMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getCacheMiss() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache miss.
getCacheQuota() - Method in class alluxio.client.file.CacheContext
 
getCacheScope() - Method in class alluxio.client.file.CacheContext
 
getCacheSize() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 cacheSize = 2;
getCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
optional int64 cacheSize = 2;
getCacheSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
optional int64 cacheSize = 2;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional bool cancel = 2;
getCancel() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional bool cancel = 2;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, this request is to cancel the reading request for the id.
getCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
If set, this request is to cancel the reading request for the id.
getCancel() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
If set, this request is to cancel the reading request for the id.
getCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
getCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool cancel = 6;
getCancel() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool cancel = 6;
getCancelledTrackers() - Method in class alluxio.master.file.contexts.OperationContext
 
getCancelMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getCancelState() - Method in class alluxio.master.file.PersistJob
 
getCancelTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
getCancelTaskCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
getCancelTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
getCancelTaskCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
getCancelTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
getCancelTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
getCancelTaskCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
getCandidates(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidates(int) - Method in class alluxio.grpc.table.EquatableValueSet
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidates(int) - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesCount() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesCount() - Method in class alluxio.grpc.table.EquatableValueSet
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesCount() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesList() - Method in class alluxio.grpc.table.EquatableValueSet
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesOrBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesOrBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesOrBuilder(int) - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesOrBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesOrBuilderList() - Method in class alluxio.grpc.table.EquatableValueSet
repeated .alluxio.grpc.table.Value candidates = 1;
getCandidatesOrBuilderList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
repeated .alluxio.grpc.table.Value candidates = 1;
getCanonical(Class<W>) - Method in class alluxio.Registry
Convenience method for Registry.getCanonical(Class, int) with default timeout.
getCanonical(Class<W>, int) - Method in class alluxio.Registry
Gets the server registered with the canonical type.
getCanonicalServiceName() - Method in class alluxio.hadoop.AbstractFileSystem
 
getCanonicalVersion() - Method in enum alluxio.underfs.hdfs.HdfsVersion
 
getCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional bool canRegisterAgain = 3;
getCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions
optional bool canRegisterAgain = 3;
getCanRegisterAgain() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
optional bool canRegisterAgain = 3;
getCapacity() - Method in class alluxio.util.webui.NodeInfo
Gets capacity.
getCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets capacity.
getCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets capacity.
getCapacityBytes() - Method in interface alluxio.client.block.BlockMasterClient
Gets the total Alluxio capacity in bytes, on all the tiers of all the workers.
getCapacityBytes() - Method in class alluxio.client.block.BlockStoreClient
Gets the total capacity of Alluxio's BlockStore.
getCapacityBytes() - Method in class alluxio.client.block.BlockWorkerInfo
 
getCapacityBytes() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getCapacityBytes() - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
getCapacityBytes(GetCapacityBytesPOptions, StreamObserver<GetCapacityBytesPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns the capacity (in bytes).
getCapacityBytes(GetCapacityBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns the capacity (in bytes).
getCapacityBytes(GetCapacityBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns the capacity (in bytes).
getCapacityBytes(GetCapacityBytesPOptions, StreamObserver<GetCapacityBytesPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns the capacity (in bytes).
getCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 capacityBytes = 1;
getCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo
optional int64 capacityBytes = 1;
getCapacityBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int64 capacityBytes = 1;
getCapacityBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 capacityBytes = 5;
getCapacityBytes() - Method in class alluxio.grpc.WorkerInfo
optional int64 capacityBytes = 5;
getCapacityBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 capacityBytes = 5;
getCapacityBytes() - Method in interface alluxio.master.block.BlockMaster
 
getCapacityBytes(GetCapacityBytesPOptions, StreamObserver<GetCapacityBytesPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getCapacityBytes() - Method in class alluxio.master.block.DefaultBlockMaster
 
getCapacityBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getCapacityBytes() - Method in class alluxio.util.webui.UIStorageDir
Gets capacity bytes.
getCapacityBytes() - Method in class alluxio.util.webui.UIUsageOnTier
Gets capacity bytes.
getCapacityBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getCapacityBytes() - Method in class alluxio.wire.WorkerInfo
 
getCapacityBytes() - Method in class alluxio.wire.WorkerWebUIOverview
Gets capacity bytes.
getCapacityBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytes() - Method in class alluxio.worker.block.BlockWorkerMetrics
 
getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageDir
Gets the total capacity of this StorageDir in bytes, which is a constant once this StorageDir has been initialized.
getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageTier
 
getCapacityBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
Deprecated.
getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions
Deprecated.
getCapacityBytesOnTiers() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
Deprecated.
getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
Deprecated.
getCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo
Deprecated.
getCapacityBytesOnTiers() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
Deprecated.
getCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
Deprecated.
getCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo
Deprecated.
getCapacityBytesOnTiers() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
Deprecated.
getCapacityBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getCapacityBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytesOnTiers() - Method in class alluxio.worker.block.BlockWorkerMetrics
 
getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
getCapacityBytesOnTiersCount() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo
 
getCapacityBytesOnTiersCount() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo.Builder
 
getCapacityBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo
 
getCapacityBytesOnTiersCount() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPOptions
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersMap() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersMap() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersMap() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPOptions
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 2;
getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo
map<string, int64> capacityBytesOnTiers = 8;
getCapacityBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> capacityBytesOnTiers = 8;
GetCapacityBytesPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetCapacityBytesPOptions
GetCapacityBytesPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetCapacityBytesPOptions
GetCapacityBytesPOptionsOrBuilder - Interface in alluxio.grpc
 
GetCapacityBytesPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetCapacityBytesPResponse
GetCapacityBytesPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetCapacityBytesPResponse
GetCapacityBytesPResponseOrBuilder - Interface in alluxio.grpc
 
getCapacityFree() - Method in class alluxio.worker.block.BlockWorkerMetrics
 
getCatchupState() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getCatchupState() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
 
getCauseType() - Method in exception alluxio.client.file.dora.netty.PartialReadException
 
getChannel() - Method in class alluxio.grpc.GrpcChannel
 
getChannel() - Method in class alluxio.network.netty.NettyRPCContext
 
getChannel() - Method in class alluxio.worker.block.io.BlockReader
Returns a readable byte channel of the block.
getChannel() - Method in class alluxio.worker.block.io.BlockWriter
 
getChannel() - Method in class alluxio.worker.dora.PagedFileReader
 
getChannel() - Method in class alluxio.worker.dora.PagedFileWriter
 
getChannelClass(boolean, PropertyKey, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Get the proper channel class.
getChannelId() - Method in class alluxio.grpc.GrpcChannelKey
 
getChannelKey() - Method in class alluxio.grpc.GrpcChannel
 
getChannelRef() - Method in class alluxio.grpc.SaslMessage.Builder
optional string channelRef = 5;
getChannelRef() - Method in class alluxio.grpc.SaslMessage
optional string channelRef = 5;
getChannelRef() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional string channelRef = 5;
getChannelRefBytes() - Method in class alluxio.grpc.SaslMessage.Builder
optional string channelRef = 5;
getChannelRefBytes() - Method in class alluxio.grpc.SaslMessage
optional string channelRef = 5;
getChannelRefBytes() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional string channelRef = 5;
getChannelType(PropertyKey, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Get the proper channel type.
getCheckAccessMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getCheckConsistencyMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getCheckContent() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool check_content = 6;
getCheckContent() - Method in class alluxio.grpc.CopyJobPOptions
optional bool check_content = 6;
getCheckContent() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool check_content = 6;
getCheckContent() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool check_content = 6;
getCheckContent() - Method in class alluxio.grpc.MoveJobPOptions
optional bool check_content = 6;
getCheckContent() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool check_content = 6;
getCheckContent() - Method in class alluxio.grpc.WriteOptions.Builder
optional bool check_content = 3;
getCheckContent() - Method in class alluxio.grpc.WriteOptions
optional bool check_content = 3;
getCheckContent() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
optional bool check_content = 3;
getCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool check_content = 11;
getCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional bool check_content = 11;
getCheckContent() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional bool check_content = 11;
getCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool check_content = 11;
getCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional bool check_content = 11;
getCheckContent() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional bool check_content = 11;
getCheckpoint() - Method in interface alluxio.master.journal.JournalReader
Returns the input stream for reading a checkpoint.
getCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
getCheckpoint() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getCheckpointFormat() - Method in enum alluxio.master.journal.checkpoint.CheckpointType
 
getCheckpointInputStream() - Method in interface alluxio.master.journalv0.JournalReader
Gets the JournalInputStream for the journal checkpoint.
getCheckpointInputStream() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
getCheckpointLastModifiedTimeMs() - Method in interface alluxio.master.journalv0.JournalReader
 
getCheckpointLastModifiedTimeMs() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
getCheckpointMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getCheckpointName() - Method in class alluxio.master.block.DefaultBlockMaster
 
getCheckpointName() - Method in class alluxio.master.block.DefaultBlockMasterContainerIdJournaled
 
getCheckpointName() - Method in class alluxio.master.file.meta.InodeCounter
 
getCheckpointName() - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
getCheckpointName() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getCheckpointName() - Method in class alluxio.master.file.meta.MountTable.State
 
getCheckpointName() - Method in class alluxio.master.file.meta.PinnedInodeFileIds
 
getCheckpointName() - Method in class alluxio.master.file.meta.ReplicationLimitedFileIds
 
getCheckpointName() - Method in class alluxio.master.file.meta.ToBePersistedFileIds
 
getCheckpointName() - Method in class alluxio.master.file.meta.TtlBucketList
 
getCheckpointName() - Method in interface alluxio.master.journal.checkpoint.Checkpointed
 
getCheckpointName() - Method in interface alluxio.master.journal.DelegatingJournaled
 
getCheckpointName() - Method in class alluxio.master.journal.JournaledGroup
 
getCheckpointName() - Method in interface alluxio.master.journal.NoopJournaled
 
getCheckpointName() - Method in class alluxio.master.journal.raft.SnapshotIdJournaled
 
getCheckpointName() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getCheckpointName() - Method in class alluxio.master.meta.DefaultMetaMaster.State
 
getCheckpointName() - Method in class alluxio.master.meta.PathProperties.State
 
getCheckpointName() - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
getCheckpointName() - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
getCheckpointName() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
getCheckpointName() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
getCheckpointName() - Method in class alluxio.master.scheduler.JournaledJobMetaStore
 
getCheckpointOutputStream(long) - Method in interface alluxio.master.journalv0.JournalWriter
Returns an output stream for the journal checkpoint.
getCheckpointOutputStream(long) - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
getCheckpoints() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getCheckpointWriter(long) - Method in class alluxio.master.journal.ufs.UfsJournal
 
getCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool checkS3BucketPath = 8;
getCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional bool checkS3BucketPath = 8;
getCheckS3BucketPath() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional bool checkS3BucketPath = 8;
getCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool checkS3BucketPath = 14;
getCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions
optional bool checkS3BucketPath = 14;
getCheckS3BucketPath() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool checkS3BucketPath = 14;
getCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
optional bool checkUfs = 1;
getCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest
optional bool checkUfs = 1;
getCheckUfs() - Method in interface alluxio.grpc.GetMountTablePRequestOrBuilder
optional bool checkUfs = 1;
getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChild(InodeDirectoryView, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
getChild(Long, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChild(Long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChild(InodeDirectoryView, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChild(InodeDirectoryView, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChild(Long, String, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
getChildCount() - Method in class alluxio.master.file.meta.InodeDirectory
 
getChildCount() - Method in interface alluxio.master.file.meta.InodeDirectoryView
 
getChildCount() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
getChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 child_count = 26;
getChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 child_count = 26;
getChildCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 child_count = 26;
getChildId() - Method in class alluxio.master.file.meta.EdgeEntry
 
getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChildId(InodeDirectoryView, String, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
getChildId(Long, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChildId(Long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChildId(InodeDirectoryView, String, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChildId(Long, String, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChildIds(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
getChildIds(Long, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
Returns an iterable for the ids of the children of the given directory.
getChildIds(Long) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChildIds(InodeDirectoryView, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
Returns an iterable for the ids of the children of the given directory.
getChildIds(Long, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
getChildName() - Method in class alluxio.master.file.meta.EdgeEntry
 
getChildName(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets the child name based on the parent name.
getChildren(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads for the children of the given node.
getChildren() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the children nodes of the node.
getChildren(int) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildren(int) - Method in class alluxio.grpc.JobInfo
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildren(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildren() - Method in interface alluxio.job.wire.JobInfo
 
getChildren() - Method in class alluxio.job.wire.PlanInfo
 
getChildren() - Method in class alluxio.job.wire.TaskInfo
 
getChildren() - Method in class alluxio.job.wire.WorkflowInfo
 
getChildren(Long, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
getChildren(Long, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
getChildren(Long, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
Returns an iterator over the children of the specified inode.
getChildren(Long) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChildren(InodeDirectoryView, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChildren(InodeDirectoryView) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
getChildren(String) - Method in class alluxio.membership.AlluxioEtcdClient
Get list of children path kv pairs from a given parentPath e.g.
getChildren(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
Get the child UfsStatuses from a given AlluxioURI.
getChildrenBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenBuilderList() - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenCount() - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenCount() - Method in class alluxio.grpc.JobInfo
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenCount() - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenFrom(long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
Returns a closeable stream of the inodes sorted by filename of the children of the given directory that come after and including fromName.
getChildrenList() - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenList() - Method in class alluxio.grpc.JobInfo
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenList() - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenOrBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenOrBuilder(int) - Method in class alluxio.grpc.JobInfo
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenOrBuilder(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenOrBuilderList() - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenOrBuilderList() - Method in class alluxio.grpc.JobInfo
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenOrBuilderList() - Method in interface alluxio.grpc.JobInfoOrBuilder
repeated .alluxio.grpc.job.JobInfo children = 11;
getChildrenPrefix(long, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
Returns a closeable stream of the inodes sorted by filename of the children of the given directory that come after and including fromName.
getChildrenPrefixFrom(long, String, String) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
Returns a closeable stream of the inodes sorted by filename of the children of the given directory that come after and including fromName, and matching the prefix.
getChunk() - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
getChunk() - Method in class alluxio.grpc.ReadResponse
optional .alluxio.grpc.block.Chunk chunk = 1;
getChunk() - Method in interface alluxio.grpc.ReadResponseOrBuilder
optional .alluxio.grpc.block.Chunk chunk = 1;
getChunk() - Method in class alluxio.grpc.SnapshotData.Builder
optional bytes chunk = 3;
getChunk() - Method in class alluxio.grpc.SnapshotData
optional bytes chunk = 3;
getChunk() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
optional bytes chunk = 3;
getChunk() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
getChunk() - Method in class alluxio.grpc.WriteRequest
.alluxio.grpc.block.Chunk chunk = 2;
getChunk() - Method in interface alluxio.grpc.WriteRequestOrBuilder
.alluxio.grpc.block.Chunk chunk = 2;
getChunkBuilder() - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
getChunkBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
getChunkOrBuilder() - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
getChunkOrBuilder() - Method in class alluxio.grpc.ReadResponse
optional .alluxio.grpc.block.Chunk chunk = 1;
getChunkOrBuilder() - Method in interface alluxio.grpc.ReadResponseOrBuilder
optional .alluxio.grpc.block.Chunk chunk = 1;
getChunkOrBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
getChunkOrBuilder() - Method in class alluxio.grpc.WriteRequest
.alluxio.grpc.block.Chunk chunk = 2;
getChunkOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
.alluxio.grpc.block.Chunk chunk = 2;
getChunkSize() - Method in class alluxio.client.file.dora.DoraCacheClient
 
getChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 chunk_size = 5;
getChunkSize() - Method in class alluxio.grpc.ReadRequest
optional int64 chunk_size = 5;
getChunkSize() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 chunk_size = 5;
getChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, the server should send packets in the specified packet size.
getChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
If set, the server should send packets in the specified packet size.
getChunkSize() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
If set, the server should send packets in the specified packet size.
getChunkSize() - Method in class alluxio.wire.BlockReadRequest
 
getClass(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as a class.
getClass(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the value for the given key as a class.
getClass(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getClass(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getClassName() - Method in enum alluxio.master.MasterHealthCheckClient.MasterType
 
getClassName() - Method in class alluxio.stress.job.StressBenchConfig
 
getClassName() - Method in interface alluxio.util.JsonSerializable
 
getCleanedPathComponents(String) - Static method in class alluxio.util.io.PathUtils
Get the components of a path that has already been cleaned.
getClearMetricsMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getClearMetricsMethod() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
 
getClient() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Returns a FileSystem client.
getClient(FileSystemContext) - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
getClient() - Method in class alluxio.master.ClientPool
Returns a FileSystem client.
getClient(FileSystemContext) - Method in class alluxio.master.ClientPool
Returns a FileSystem client using a specific context.
getClient() - Method in class alluxio.master.LocalAlluxioCluster
 
getClient(FileSystemContext) - Method in class alluxio.master.LocalAlluxioCluster
 
getClient() - Method in class alluxio.master.LocalAlluxioMaster
 
getClient(FileSystemContext) - Method in class alluxio.master.LocalAlluxioMaster
 
getClient() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
getClient(FileSystemContext) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
getClient() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getClient(FileSystemContext) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getClient(String, String, String, int, boolean) - Static method in class alluxio.master.ZkMasterInquireClient
Gets the client.
getClient() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
getClient() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
getClient() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
getClient() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
getClient() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
getClient() - Method in class alluxio.underfs.s3a.S3AInputStream
 
getClient() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
getClient() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
getClient() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getClientChannelClass(boolean) - Static method in class alluxio.util.network.NettyUtils
Returns the correct SocketChannel class based on ChannelType.
getClientContext() - Method in class alluxio.client.file.FileSystemContext
 
getClientHostName(AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the local hostname to be used by the client.
getClientId() - Method in class alluxio.grpc.SaslMessage.Builder
optional string clientId = 3;
getClientId() - Method in class alluxio.grpc.SaslMessage
optional string clientId = 3;
getClientId() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional string clientId = 3;
getClientIdBytes() - Method in class alluxio.grpc.SaslMessage.Builder
optional string clientId = 3;
getClientIdBytes() - Method in class alluxio.grpc.SaslMessage
optional string clientId = 3;
getClientIdBytes() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional string clientId = 3;
getClientList() - Method in class alluxio.worker.block.BlockMasterClientPool
 
getClientMetrics(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetrics(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetrics(int) - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsBuilder(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsBuilderList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsCount() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsCount() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsCount() - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsList() - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsOrBuilder(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsOrBuilder(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsOrBuilder(int) - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsOrBuilderList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsOrBuilderList() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClientMetricsOrBuilderList() - Method in interface alluxio.grpc.MetricsHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
getClients() - Method in class alluxio.multi.process.MultiProcessCluster
 
getClientSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getClientSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getClientUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the user name from the ThreadLocal variable.
getClientVersion() - Static method in class alluxio.security.authentication.ClientContextServerInjector
 
getClock() - Method in interface alluxio.master.block.BlockMaster
Returns the BlockMaster's clock so other components can align with the BlockMaster's time.
getClock() - Method in class alluxio.master.block.DefaultBlockMaster
 
getClock() - Method in class alluxio.time.TimeContext
 
getCloseableIterator() - Method in interface alluxio.master.metastore.BlockMetaStore
Gets a CloseableIterator over the blocks.
getCloseableIterator() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
getCloseableIterator() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
getCloseableIterator() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
Acquires an iterator to iterate all Inodes in RocksDB.
getCloser() - Method in class alluxio.cli.fsadmin.command.Context
 
getCloser() - Method in class alluxio.grpc.GrpcService
Gets the closer associated with this service.
getClusterConf() - Method in class alluxio.client.file.FileSystemContext
 
getClusterConf() - Method in class alluxio.ClientContext
 
getClusterConf(GetConfigurationPResponse, AlluxioConfiguration, Scope) - Static method in class alluxio.conf.Configuration
Loads the cluster level configuration from the get configuration response, filters out the configuration for certain scope, and merges it with the existing configuration.
getClusterConf() - Method in class alluxio.wire.Configuration
 
getClusterConfHash() - Method in class alluxio.ClientContext
 
getClusterConfHash() - Method in class alluxio.wire.Configuration
 
getClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string clusterConfigHash = 1;
getClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
optional string clusterConfigHash = 1;
getClusterConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
optional string clusterConfigHash = 1;
getClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string clusterConfigHash = 3;
getClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
optional string clusterConfigHash = 3;
getClusterConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional string clusterConfigHash = 3;
getClusterConfigHash() - Method in class alluxio.wire.ConfigHash
 
getClusterConfigHash() - Method in class alluxio.wire.WorkerWebUIConfiguration
 
getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string clusterConfigHash = 1;
getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse
optional string clusterConfigHash = 1;
getClusterConfigHashBytes() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
optional string clusterConfigHash = 1;
getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string clusterConfigHash = 3;
getClusterConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse
optional string clusterConfigHash = 3;
getClusterConfigHashBytes() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional string clusterConfigHash = 3;
getClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 clusterConfigLastUpdateTime = 5;
getClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
optional int64 clusterConfigLastUpdateTime = 5;
getClusterConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional int64 clusterConfigLastUpdateTime = 5;
getClusterConfigLastUpdateTime() - Method in class alluxio.wire.ConfigHash
 
getClusterConfigLastUpdateTime() - Method in class alluxio.wire.WorkerWebUIConfiguration
 
getClusterConfigLastUpdateTimeText() - Method in class alluxio.wire.ConfigHash
 
getClusterConfigs(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigs(int) - Method in class alluxio.grpc.GetConfigurationPResponse
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigs(int) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsBuilder(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsBuilderList() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsCount() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsList() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsList() - Method in class alluxio.grpc.GetConfigurationPResponse
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsList() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsOrBuilder(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsOrBuilder(int) - Method in class alluxio.grpc.GetConfigurationPResponse
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsOrBuilder(int) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsOrBuilderList() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsOrBuilderList() - Method in class alluxio.grpc.GetConfigurationPResponse
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfigsOrBuilderList() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
getClusterConfLastUpdateTime() - Method in class alluxio.wire.Configuration
 
getClusterId() - Method in class alluxio.grpc.MasterInfo.Builder
optional string clusterId = 11;
getClusterId() - Method in class alluxio.grpc.MasterInfo
optional string clusterId = 11;
getClusterId() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string clusterId = 11;
getClusterID() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getClusterID() - Method in class alluxio.master.meta.DefaultMetaMaster.State
 
getClusterID() - Method in interface alluxio.master.meta.MetaMaster
 
getClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
optional string cluster_id = 1;
getClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
optional string cluster_id = 1;
getClusterId() - Method in interface alluxio.proto.journal.Meta.ClusterInfoEntryOrBuilder
optional string cluster_id = 1;
getClusterId() - Method in class alluxio.wire.MasterWebUIOverview
Gets cluster id.
getClusterIdBytes() - Method in class alluxio.grpc.MasterInfo.Builder
optional string clusterId = 11;
getClusterIdBytes() - Method in class alluxio.grpc.MasterInfo
optional string clusterId = 11;
getClusterIdBytes() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string clusterId = 11;
getClusterIdBytes() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
optional string cluster_id = 1;
getClusterIdBytes() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
optional string cluster_id = 1;
getClusterIdBytes() - Method in interface alluxio.proto.journal.Meta.ClusterInfoEntryOrBuilder
optional string cluster_id = 1;
getClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
getClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
getClusterInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
getClusterInfoBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
getClusterInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
getClusterInfoOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
getClusterInfoOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
getClusterLimit() - Method in class alluxio.stress.job.StressBenchConfig
 
getCmd() - Method in class alluxio.shell.CommandReturn
Gets the command run.
getCmdConfig() - Method in class alluxio.grpc.SubmitRequest.Builder
optional bytes cmdConfig = 1;
getCmdConfig() - Method in class alluxio.grpc.SubmitRequest
optional bytes cmdConfig = 1;
getCmdConfig() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
optional bytes cmdConfig = 1;
getCmdProgress() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
getCmdProgress() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
getCmdProgress() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
getCmdProgressBuilder() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
getCmdProgressOrBuilder() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
getCmdProgressOrBuilder() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
getCmdProgressOrBuilder() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
getCmdRunAttempt() - Method in class alluxio.master.job.common.CmdInfo
Get CmdRunAttempt.
getCmdStatus(long) - Method in interface alluxio.client.job.JobMasterClient
Gets the status of the given command jobControlId.
getCmdStatus(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
optional .alluxio.grpc.job.Status cmdStatus = 1;
getCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse
optional .alluxio.grpc.job.Status cmdStatus = 1;
getCmdStatus() - Method in interface alluxio.grpc.GetCmdStatusResponseOrBuilder
optional .alluxio.grpc.job.Status cmdStatus = 1;
getCmdStatus(GetCmdStatusRequest, StreamObserver<GetCmdStatusResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Get status for a CMD job, return a status.
getCmdStatus(GetCmdStatusRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Get status for a CMD job, return a status.
getCmdStatus(GetCmdStatusRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Get status for a CMD job, return a status.
getCmdStatus(GetCmdStatusRequest, StreamObserver<GetCmdStatusResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Get status for a CMD job, return a status.
getCmdStatus(long) - Method in class alluxio.master.job.JobMaster
Get command status.
getCmdStatus(GetCmdStatusRequest, StreamObserver<GetCmdStatusResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
getCmdStatus(long) - Method in class alluxio.master.job.tracker.CmdJobTracker
Get status information for a CMD.
getCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
getCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
getCmdStatusBlock() - Method in interface alluxio.grpc.GetCmdStatusDetailedResponseOrBuilder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
getCmdStatusBlock(long) - Method in class alluxio.master.job.tracker.CmdJobTracker
Get a cmdStatusBlock information.
getCmdStatusBlockBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
getCmdStatusBlockOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
getCmdStatusBlockOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
getCmdStatusBlockOrBuilder() - Method in interface alluxio.grpc.GetCmdStatusDetailedResponseOrBuilder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
getCmdStatusDetailed(long) - Method in interface alluxio.client.job.JobMasterClient
Gets the detailed status of the given command jobControlId.
getCmdStatusDetailed(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getCmdStatusDetailed(GetCmdStatusDetailedRequest, StreamObserver<GetCmdStatusDetailedResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Get detailed status for a CMD job, return detailed status information.
getCmdStatusDetailed(GetCmdStatusDetailedRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Get detailed status for a CMD job, return detailed status information.
getCmdStatusDetailed(GetCmdStatusDetailedRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Get detailed status for a CMD job, return detailed status information.
getCmdStatusDetailed(GetCmdStatusDetailedRequest, StreamObserver<GetCmdStatusDetailedResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Get detailed status for a CMD job, return detailed status information.
getCmdStatusDetailed(long) - Method in class alluxio.master.job.JobMaster
 
getCmdStatusDetailed(GetCmdStatusDetailedRequest, StreamObserver<GetCmdStatusDetailedResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
GetCmdStatusDetailedOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedOptions
GetCmdStatusDetailedOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedOptions
GetCmdStatusDetailedOptionsOrBuilder - Interface in alluxio.grpc
 
GetCmdStatusDetailedRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedRequest
GetCmdStatusDetailedRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedRequest
GetCmdStatusDetailedRequestOrBuilder - Interface in alluxio.grpc
 
GetCmdStatusDetailedResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedResponse
GetCmdStatusDetailedResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusDetailedResponse
GetCmdStatusDetailedResponseOrBuilder - Interface in alluxio.grpc
 
GetCmdStatusOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusOptions
GetCmdStatusOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusOptions
GetCmdStatusOptionsOrBuilder - Interface in alluxio.grpc
 
GetCmdStatusRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusRequest
GetCmdStatusRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusRequest
GetCmdStatusRequestOrBuilder - Interface in alluxio.grpc
 
GetCmdStatusResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusResponse
GetCmdStatusResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetCmdStatusResponse
GetCmdStatusResponseOrBuilder - Interface in alluxio.grpc
 
getCode() - Method in enum alluxio.cli.fsadmin.command.DecommissionWorkerCommand.ReturnCode
Gets the code.
getCode() - Method in class alluxio.grpc.BlockStatus.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.grpc.BlockStatus
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in interface alluxio.grpc.BlockStatusOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.grpc.FileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.grpc.FileFailure
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in interface alluxio.grpc.FileFailureOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.grpc.LoadFileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.grpc.LoadFileFailure
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.grpc.RouteFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.grpc.RouteFailure
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in interface alluxio.grpc.RouteFailureOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
getCode() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getCode() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
getCode() - Method in class alluxio.s3.S3Error
 
getCode() - Method in class alluxio.s3.S3ErrorCode
 
getCollectionCount() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getCollectionTime() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_name = 1;
getColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional string col_name = 1;
getColName() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional string col_name = 1;
getColNameBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_name = 1;
getColNameBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional string col_name = 1;
getColNameBytes() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional string col_name = 1;
getColNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string col_names = 3;
getColNames(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getColNames(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNames(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
repeated string col_names = 3;
getColNames(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getColNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string col_names = 3;
getColNamesBytes(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getColNamesBytes(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNamesBytes(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
repeated string col_names = 3;
getColNamesBytes(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getColNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string col_names = 3;
getColNamesCount() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getColNamesCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNamesCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
repeated string col_names = 3;
getColNamesCount() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getColNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string col_names = 3;
getColNamesList() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getColNamesList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
getColNamesList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
repeated string col_names = 3;
getColNamesList() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
repeated string col_names = 3;
getCols(int) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getCols(int) - Method in class alluxio.grpc.table.Schema
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getCols(int) - Method in interface alluxio.grpc.table.SchemaOrBuilder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsBuilder(int) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsBuilderList() - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsCount() - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsCount() - Method in class alluxio.grpc.table.Schema
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsCount() - Method in interface alluxio.grpc.table.SchemaOrBuilder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsList() - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsList() - Method in class alluxio.grpc.table.Schema
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsList() - Method in interface alluxio.grpc.table.SchemaOrBuilder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsOrBuilder(int) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsOrBuilder(int) - Method in class alluxio.grpc.table.Schema
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsOrBuilder(int) - Method in interface alluxio.grpc.table.SchemaOrBuilder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsOrBuilderList() - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsOrBuilderList() - Method in class alluxio.grpc.table.Schema
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColsOrBuilderList() - Method in interface alluxio.grpc.table.SchemaOrBuilder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
getColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_type = 2;
getColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional string col_type = 2;
getColType() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional string col_type = 2;
getColTypeBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_type = 2;
getColTypeBytes() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional string col_type = 2;
getColTypeBytes() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional string col_type = 2;
getColumn() - Method in class alluxio.grpc.table.FileStatistics.Builder
Deprecated.
getColumn() - Method in class alluxio.grpc.table.FileStatistics
Deprecated.
getColumn() - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
Deprecated.
getColumnConstraints() - Method in class alluxio.grpc.table.Constraint.Builder
Deprecated.
getColumnConstraints() - Method in class alluxio.grpc.table.Constraint
Deprecated.
getColumnConstraints() - Method in interface alluxio.grpc.table.ConstraintOrBuilder
Deprecated.
getColumnConstraintsCount() - Method in class alluxio.grpc.table.Constraint.Builder
 
getColumnConstraintsCount() - Method in class alluxio.grpc.table.Constraint
 
getColumnConstraintsCount() - Method in interface alluxio.grpc.table.ConstraintOrBuilder
maps column to constraint, columns not present are not constrained
getColumnConstraintsMap() - Method in class alluxio.grpc.table.Constraint.Builder
maps column to constraint, columns not present are not constrained
getColumnConstraintsMap() - Method in class alluxio.grpc.table.Constraint
maps column to constraint, columns not present are not constrained
getColumnConstraintsMap() - Method in interface alluxio.grpc.table.ConstraintOrBuilder
maps column to constraint, columns not present are not constrained
getColumnConstraintsOrDefault(String, Domain) - Method in class alluxio.grpc.table.Constraint.Builder
maps column to constraint, columns not present are not constrained
getColumnConstraintsOrDefault(String, Domain) - Method in class alluxio.grpc.table.Constraint
maps column to constraint, columns not present are not constrained
getColumnConstraintsOrDefault(String, Domain) - Method in interface alluxio.grpc.table.ConstraintOrBuilder
maps column to constraint, columns not present are not constrained
getColumnConstraintsOrThrow(String) - Method in class alluxio.grpc.table.Constraint.Builder
maps column to constraint, columns not present are not constrained
getColumnConstraintsOrThrow(String) - Method in class alluxio.grpc.table.Constraint
maps column to constraint, columns not present are not constrained
getColumnConstraintsOrThrow(String) - Method in interface alluxio.grpc.table.ConstraintOrBuilder
maps column to constraint, columns not present are not constrained
getColumnCount() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
getColumnCount() - Method in class alluxio.grpc.table.FileStatistics
 
getColumnCount() - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
map column names to column statistics
getColumnMap() - Method in class alluxio.grpc.table.FileStatistics.Builder
map column names to column statistics
getColumnMap() - Method in class alluxio.grpc.table.FileStatistics
map column names to column statistics
getColumnMap() - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
map column names to column statistics
getColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required string column_name = 1;
getColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
required string column_name = 1;
getColumnName() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
required string column_name = 1;
getColumnNameBytes() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required string column_name = 1;
getColumnNameBytes() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
required string column_name = 1;
getColumnNameBytes() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
required string column_name = 1;
getColumnOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.FileStatistics.Builder
map column names to column statistics
getColumnOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.FileStatistics
map column names to column statistics
getColumnOrDefault(String, ColumnStatisticsInfo) - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
map column names to column statistics
getColumnOrThrow(String) - Method in class alluxio.grpc.table.FileStatistics.Builder
map column names to column statistics
getColumnOrThrow(String) - Method in class alluxio.grpc.table.FileStatistics
map column names to column statistics
getColumnOrThrow(String) - Method in interface alluxio.grpc.table.FileStatisticsOrBuilder
map column names to column statistics
getCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
getCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse
optional .alluxio.grpc.Command command = 1;
getCommand() - Method in interface alluxio.grpc.BlockHeartbeatPResponseOrBuilder
optional .alluxio.grpc.Command command = 1;
getCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
getCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
optional .alluxio.grpc.file.FileSystemCommand command = 1;
getCommand() - Method in interface alluxio.grpc.FileSystemHeartbeatPResponseOrBuilder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
getCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
getCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
getCommand() - Method in interface alluxio.grpc.JobMasterHeartbeatPResponseOrBuilder
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
getCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
optional .alluxio.grpc.meta.MetaCommand command = 1;
getCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse
optional .alluxio.grpc.meta.MetaCommand command = 1;
getCommand() - Method in interface alluxio.grpc.MasterHeartbeatPResponseOrBuilder
optional .alluxio.grpc.meta.MetaCommand command = 1;
getCommand() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
getCommand() - Method in class alluxio.grpc.WriteRequest
.alluxio.grpc.block.WriteRequestCommand command = 1;
getCommand() - Method in interface alluxio.grpc.WriteRequestOrBuilder
.alluxio.grpc.block.WriteRequestCommand command = 1;
getCommand() - Method in class alluxio.shell.ShellCommand
Gets the command.
getCommandBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
getCommandBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
getCommandBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
getCommandName() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
 
getCommandName() - Method in class alluxio.cli.bundler.command.CollectConfigCommand
 
getCommandName() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
 
getCommandName() - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
 
getCommandName() - Method in class alluxio.cli.bundler.command.CollectLogCommand
 
getCommandName() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
 
getCommandName() - Method in interface alluxio.cli.Command
Gets the command name as input from the shell.
getCommandName() - Method in class alluxio.cli.command.metadatacache.DropAllCommand
 
getCommandName() - Method in class alluxio.cli.command.metadatacache.DropCommand
 
getCommandName() - Method in class alluxio.cli.command.metadatacache.SizeCommand
 
getCommandName() - Method in class alluxio.cli.command.MetadataCacheCommand
 
getCommandName() - Method in class alluxio.cli.extensions.command.InstallCommand
 
getCommandName() - Method in class alluxio.cli.extensions.command.LsCommand
 
getCommandName() - Method in class alluxio.cli.extensions.command.UninstallCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.CatCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.CheckCachedCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.ChecksumCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.ChgrpCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.ChmodCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.ChownCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.CpCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.FreeCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.HeadCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.HelpCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.LoadCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.LocationCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.LsCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.MkdirCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.MvCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.RmCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.StatCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.TailCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.TestCommand
 
getCommandName() - Method in class alluxio.cli.fs.command.TouchCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.JournalCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.NodesCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
getCommandName() - Method in class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
 
getCommandOptions() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
getCommandOptions() - Method in class alluxio.grpc.FileSystemCommand
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
getCommandOptions() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
getCommandOptions() - Method in class alluxio.wire.FileSystemCommand
 
getCommandOptionsBuilder() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
getCommandOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
getCommandOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommand
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
getCommandOptionsOrBuilder() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
getCommandOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
getCommandOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse
optional .alluxio.grpc.Command command = 1;
getCommandOrBuilder() - Method in interface alluxio.grpc.BlockHeartbeatPResponseOrBuilder
optional .alluxio.grpc.Command command = 1;
getCommandOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
getCommandOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
optional .alluxio.grpc.file.FileSystemCommand command = 1;
getCommandOrBuilder() - Method in interface alluxio.grpc.FileSystemHeartbeatPResponseOrBuilder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
getCommandOrBuilder() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
getCommandOrBuilder() - Method in class alluxio.grpc.WriteRequest
.alluxio.grpc.block.WriteRequestCommand command = 1;
getCommandOrBuilder() - Method in interface alluxio.grpc.WriteRequestOrBuilder
.alluxio.grpc.block.WriteRequestCommand command = 1;
getCommands() - Method in class alluxio.cli.AbstractShell
 
getCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommands(int) - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsCount() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsCount() - Method in class alluxio.grpc.JobHeartbeatPResponse
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsCount() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsList() - Method in class alluxio.grpc.JobHeartbeatPResponse
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsList() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsOrBuilder(int) - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPResponse
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandsOrBuilderList() - Method in interface alluxio.grpc.JobHeartbeatPResponseOrBuilder
repeated .alluxio.grpc.job.JobCommand commands = 1;
getCommandType() - Method in class alluxio.grpc.Command.Builder
optional .alluxio.grpc.CommandType commandType = 1;
getCommandType() - Method in class alluxio.grpc.Command
optional .alluxio.grpc.CommandType commandType = 1;
getCommandType() - Method in interface alluxio.grpc.CommandOrBuilder
optional .alluxio.grpc.CommandType commandType = 1;
getCommandType() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.CommandType commandType = 1;
getCommandType() - Method in class alluxio.grpc.FileSystemCommand
optional .alluxio.grpc.CommandType commandType = 1;
getCommandType() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
optional .alluxio.grpc.CommandType commandType = 1;
getCommandType() - Method in class alluxio.wire.FileSystemCommand
 
getComment() - Method in class alluxio.grpc.table.Database.Builder
optional string comment = 7;
getComment() - Method in class alluxio.grpc.table.Database
optional string comment = 7;
getComment() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string comment = 7;
getComment() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string comment = 4;
getComment() - Method in class alluxio.grpc.table.FieldSchema
optional string comment = 4;
getComment() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string comment = 4;
getCommentBytes() - Method in class alluxio.grpc.table.Database.Builder
optional string comment = 7;
getCommentBytes() - Method in class alluxio.grpc.table.Database
optional string comment = 7;
getCommentBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string comment = 7;
getCommentBytes() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string comment = 4;
getCommentBytes() - Method in class alluxio.grpc.table.FieldSchema
optional string comment = 4;
getCommentBytes() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string comment = 4;
getCommitBlockMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getCommitPath() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getCommittedBytes() - Method in interface alluxio.worker.block.meta.StorageDir
Gets the total size of committed blocks in this StorageDir in bytes.
getCommonOptions() - Method in class alluxio.client.file.options.OutStreamOptions
 
getCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
getCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
getCommonOptions() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
getCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptions() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in class alluxio.grpc.DeletePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in class alluxio.grpc.ExistsPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.FreePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in class alluxio.grpc.MountPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.RenamePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.SetAclPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptions() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptions() - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.grpc.UnmountPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.grpc.UnmountPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
getCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
getCommonOptions() - Method in interface alluxio.proto.client.Cache.PRocksPageStoreOptionsOrBuilder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
getCommonOptionsBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsBuilder() - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsBuilder() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsBuilder() - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsBuilder() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsBuilder() - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsBuilder() - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsBuilder() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.DeletePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.FreePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.MountPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.grpc.UnmountPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
getCommonOptionsOrBuilder() - Method in interface alluxio.proto.client.Cache.PRocksPageStoreOptionsOrBuilder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
getCommonPoolParallelism() - Static method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the targeted parallelism level of the common pool.
getCommonPrefixes() - Method in class alluxio.s3.ListBucketResult
 
getCommonPrefixes() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Use common prefixes to infer pseudo-directories in object store.
getCommonPrefixes() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
 
getCommonPrefixes() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunkV1
 
getCompleted() - Method in class alluxio.grpc.FileInfo.Builder
optional bool completed = 8;
getCompleted() - Method in class alluxio.grpc.FileInfo
optional bool completed = 8;
getCompleted() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool completed = 8;
getCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool completed = 10;
getCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool completed = 10;
getCompleted() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool completed = 10;
getCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool completed = 4;
getCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional bool completed = 4;
getCompleted() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional bool completed = 4;
getCompletedCmdCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Gets the number of completed commands.
getCompletedCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Gets the number of completed jobs.
getCompletedLocation() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getCompletedLog(long) - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
getCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
getCompleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
getCompleteFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
getCompleteFileMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getCompleteFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getCompleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
getCompleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
getCompleteFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
getCompleter() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the completer established in this task's constructor, or null if none.
GetConf - Class in alluxio.cli
Utility for printing Alluxio configuration.
getConf(ClientContext, String...) - Static method in class alluxio.cli.GetConf
Implements get configuration.
getConf() - Method in class alluxio.client.file.cache.LocalCacheFileSystem
 
getConf() - Method in class alluxio.client.file.DelegatingFileSystem
 
getConf() - Method in interface alluxio.client.file.FileSystem
 
getConf() - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
getConf() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getConf() - Method in class alluxio.multi.process.BaseMaster
 
getConfAddress() - Method in class alluxio.AbstractClient
By default, return the same underlying address as AbstractClient.getRemoteSockAddress().
getConfAddress() - Method in class alluxio.AbstractJobMasterClient
 
getConfAddress() - Method in class alluxio.AbstractMasterClient
 
getConfAddress() - Method in interface alluxio.Client
 
getConfigCheckErrorNum() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check error num.
getConfigCheckErrors() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check errors.
getConfigCheckReport() - Method in class alluxio.master.meta.checkconf.ConfigurationChecker
 
getConfigCheckReport() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getConfigCheckReport() - Method in interface alluxio.master.meta.MetaMaster
 
getConfigCheckStatus() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check status.
getConfigCheckWarnNum() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check warn num.
getConfigCheckWarns() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check warns.
getConfigErrors() - Method in class alluxio.wire.ConfigCheckReport
 
getConfigHash() - Method in interface alluxio.client.meta.MetaMasterConfigClient
 
getConfigHash() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
getConfigHash(GetConfigHashPOptions, StreamObserver<GetConfigHashPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
Returns the hashes of cluster and path level configurations.
getConfigHash(GetConfigHashPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
Returns the hashes of cluster and path level configurations.
getConfigHash(GetConfigHashPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
Returns the hashes of cluster and path level configurations.
getConfigHash(GetConfigHashPOptions, StreamObserver<GetConfigHashPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
Returns the hashes of cluster and path level configurations.
getConfigHash() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getConfigHash() - Method in interface alluxio.master.meta.MetaMaster
 
getConfigHash(GetConfigHashPOptions, StreamObserver<GetConfigHashPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
 
getConfigHash() - Method in class alluxio.wire.MasterWebUIConfiguration
 
GetConfigHashPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigHashPOptions
GetConfigHashPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigHashPOptions
GetConfigHashPOptionsOrBuilder - Interface in alluxio.grpc
 
GetConfigHashPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigHashPResponse
GetConfigHashPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigHashPResponse
GetConfigHashPResponseOrBuilder - Interface in alluxio.grpc
 
getConfigReport() - Method in interface alluxio.client.meta.MetaMasterClient
Gets the server-side configuration check report.
getConfigReport() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
getConfigReport(GetConfigReportPOptions, StreamObserver<GetConfigReportPResponse>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
Returns server-side configuration report.
getConfigReport(GetConfigReportPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
Returns server-side configuration report.
getConfigReport(GetConfigReportPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
Returns server-side configuration report.
getConfigReport(GetConfigReportPOptions, StreamObserver<GetConfigReportPResponse>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
Returns server-side configuration report.
getConfigReport(GetConfigReportPOptions, StreamObserver<GetConfigReportPResponse>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
GetConfigReportPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigReportPOptions
GetConfigReportPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigReportPOptions
GetConfigReportPOptionsOrBuilder - Interface in alluxio.grpc
 
GetConfigReportPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigReportPResponse
GetConfigReportPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigReportPResponse
GetConfigReportPResponseOrBuilder - Interface in alluxio.grpc
 
getConfigs(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigs(int) - Method in class alluxio.grpc.RegisterMasterPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigs(int) - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigs(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigs(int) - Method in class alluxio.grpc.RegisterWorkerPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigs(int) - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsBuilder(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsBuilderList() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsBuilderList() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsCount() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsCount() - Method in class alluxio.grpc.RegisterMasterPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsCount() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsCount() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsCount() - Method in class alluxio.grpc.RegisterWorkerPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsCount() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsList() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsList() - Method in class alluxio.grpc.RegisterMasterPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsList() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsList() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsList() - Method in class alluxio.grpc.RegisterWorkerPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsList() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterMasterPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilder(int) - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilder(int) - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterMasterPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilderList() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPOptions
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigsOrBuilderList() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
repeated .alluxio.grpc.ConfigProperty configs = 1;
getConfigStatus() - Method in class alluxio.wire.ConfigCheckReport
 
getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.client.meta.MetaMasterConfigClient
 
getConfiguration(GetConfigurationPOptions) - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
getConfiguration() - Method in class alluxio.common.RpcPortHealthCheckClient
 
getConfiguration() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getConfiguration(Scope) - Static method in class alluxio.conf.Configuration
Gets all configuration properties filtered by the specified scope.
getConfiguration() - Method in class alluxio.grpc.GrpcChannelBuilder
 
getConfiguration(GetConfigurationPOptions, StreamObserver<GetConfigurationPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
Returns a list of Alluxio runtime configuration information.
getConfiguration(GetConfigurationPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
Returns a list of Alluxio runtime configuration information.
getConfiguration(GetConfigurationPOptions) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
Returns a list of Alluxio runtime configuration information.
getConfiguration(GetConfigurationPOptions, StreamObserver<GetConfigurationPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
Returns a list of Alluxio runtime configuration information.
getConfiguration(GetConfigurationPOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
 
getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.master.meta.MetaMaster
 
getConfiguration(GetConfigurationPOptions, StreamObserver<GetConfigurationPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
 
getConfiguration() - Method in class alluxio.underfs.BaseUnderFileSystem
 
getConfiguration() - Method in interface alluxio.underfs.UnderFileSystem
Gets the under file system configuration.
getConfiguration() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getConfiguration() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioMasterInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioProxyInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getConfiguration() - Method in class alluxio.wire.MasterWebUIConfiguration
Gets configuration.
getConfiguration() - Method in class alluxio.wire.WorkerWebUIConfiguration
Gets configuration.
getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.worker.block.BlockWorker
 
getConfigurationFromHadoop(Configuration) - Static method in class alluxio.hadoop.HadoopConfigurationUtils
Extracts relevant configuration from Hadoop Configuration.
getConfigurationFromUri(URI, Configuration) - Method in class alluxio.hadoop.AbstractFileSystem
Gets the connection configuration from the input uri.
getConfigurationFromUri(URI, Configuration) - Method in class alluxio.hadoop.FileSystem
 
GetConfigurationPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigurationPOptions
GetConfigurationPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigurationPOptions
GetConfigurationPOptionsOrBuilder - Interface in alluxio.grpc
 
GetConfigurationPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigurationPResponse
GetConfigurationPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetConfigurationPResponse
GetConfigurationPResponseOrBuilder - Interface in alluxio.grpc
 
getConfigWarns() - Method in class alluxio.wire.ConfigCheckReport
 
getConfImpl(Supplier<RetryHandlingMetaMasterConfigClient>, AlluxioConfiguration, String...) - Static method in class alluxio.cli.GetConf
Implements get configuration.
getConfMap() - Method in class alluxio.master.meta.checkconf.ConfigurationStore
 
getConfMasterInquireClient() - Method in class alluxio.master.MasterClientContext
 
getConfMasterInquireClient() - Method in class alluxio.worker.job.JobMasterClientContext
 
getConnectAddress(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the InetSocketAddress address for client to communicate with the service.
getConnectAddress() - Method in class alluxio.worker.DataServerFactory
Get gRPC connect address.
getConnectDetails(AlluxioConfiguration) - Static method in class alluxio.master.MasterInquireClient.Factory
 
getConnectDetails() - Method in interface alluxio.master.MasterInquireClient
Returns canonical connect details representing how this client connects to the master.
getConnectDetails() - Method in class alluxio.master.PollingMasterInquireClient
 
getConnectDetails() - Method in class alluxio.master.SingleMasterInquireClient
 
getConnectDetails() - Method in class alluxio.master.ZkMasterInquireClient
 
getConnectHost(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Provides an externally resolvable hostname for client to communicate with the service.
getConnection() - Method in class alluxio.master.backup.BackupHandshakeMessage
 
getConnectionUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the connection user name from the ThreadLocal variable.
getConnectionUserName() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
getConnectMethod() - Static method in class alluxio.grpc.MessagingServiceGrpc
 
getConsistencyLevel() - Method in class alluxio.conf.PropertyKey
 
getConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
getConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest
optional .alluxio.grpc.table.Constraint constraint = 3;
getConstraint() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional .alluxio.grpc.table.Constraint constraint = 3;
getConstraintBuilder() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
getConstraintOrBuilder() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
getConstraintOrBuilder() - Method in class alluxio.grpc.table.ReadTablePRequest
optional .alluxio.grpc.table.Constraint constraint = 3;
getConstraintOrBuilder() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional .alluxio.grpc.table.Constraint constraint = 3;
getContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string containerHost = 7;
getContainerHost() - Method in class alluxio.grpc.WorkerNetAddress
optional string containerHost = 7;
getContainerHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string containerHost = 7;
getContainerHost() - Method in class alluxio.wire.WorkerNetAddress
 
getContainerHostBytes() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string containerHost = 7;
getContainerHostBytes() - Method in class alluxio.grpc.WorkerNetAddress
optional string containerHost = 7;
getContainerHostBytes() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string containerHost = 7;
getContainerId(long) - Static method in class alluxio.master.block.BlockId
 
getContainerId() - Method in class alluxio.master.file.state.DirectoryId
 
getContainerId() - Method in interface alluxio.master.file.state.DirectoryId.UnmodifiableDirectoryId
 
getContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
getContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
optional int64 container_id = 1;
getContainerId() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
optional int64 container_id = 1;
getContentHash() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional string contentHash = 4;
getContentHash() - Method in class alluxio.grpc.CompleteFilePOptions
optional string contentHash = 4;
getContentHash() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional string contentHash = 4;
getContentHash() - Method in class alluxio.grpc.FileInfo.Builder
optional string contentHash = 34;
getContentHash() - Method in class alluxio.grpc.FileInfo
optional string contentHash = 34;
getContentHash() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string contentHash = 34;
getContentHash() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional string content_hash = 1;
getContentHash() - Method in class alluxio.grpc.UfsFileStatus
optional string content_hash = 1;
getContentHash() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
optional string content_hash = 1;
getContentHash() - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
getContentHash() - Method in class alluxio.grpc.WriteResponse
Errors will be handled by standard gRPC stream APIs.
getContentHash() - Method in interface alluxio.grpc.WriteResponseOrBuilder
Errors will be handled by standard gRPC stream APIs.
getContentHash() - Method in class alluxio.underfs.AtomicFileOutputStream
 
getContentHash() - Method in interface alluxio.underfs.ContentHashable
 
getContentHash() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
getContentHash() - Method in class alluxio.underfs.cos.COSOutputStream
 
getContentHash() - Method in class alluxio.underfs.gcs.GCSOutputStream
 
getContentHash() - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
 
getContentHash() - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
getContentHash() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
getContentHash() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
getContentHash() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
getContentHash() - Method in class alluxio.underfs.obs.OBSOutputStream
 
getContentHash() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
getContentHash() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
getContentHash() - Method in class alluxio.underfs.oss.OSSOutputStream
 
getContentHash() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
getContentHash() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
getContentHash() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
getContentHash() - Method in class alluxio.underfs.UfsFileStatus
 
getContentHash() - Method in class alluxio.wire.FileInfo
 
getContentHash() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getContentHashBytes() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional string contentHash = 4;
getContentHashBytes() - Method in class alluxio.grpc.CompleteFilePOptions
optional string contentHash = 4;
getContentHashBytes() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional string contentHash = 4;
getContentHashBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string contentHash = 34;
getContentHashBytes() - Method in class alluxio.grpc.FileInfo
optional string contentHash = 34;
getContentHashBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string contentHash = 34;
getContentHashBytes() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional string content_hash = 1;
getContentHashBytes() - Method in class alluxio.grpc.UfsFileStatus
optional string content_hash = 1;
getContentHashBytes() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
optional string content_hash = 1;
getContentHashBytes() - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
getContentHashBytes() - Method in class alluxio.grpc.WriteResponse
Errors will be handled by standard gRPC stream APIs.
getContentHashBytes() - Method in interface alluxio.grpc.WriteResponseOrBuilder
Errors will be handled by standard gRPC stream APIs.
getContentLength() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 content_length = 2;
getContentLength() - Method in class alluxio.grpc.UfsFileStatus
optional int64 content_length = 2;
getContentLength() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
optional int64 content_length = 2;
getContentLength() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the size of object contents in bytes.
getContentLength() - Method in class alluxio.underfs.UfsFileStatus
Get the content size in bytes.
getContents() - Method in class alluxio.s3.ListBucketResult
 
getContext() - Method in class alluxio.client.file.dora.DoraCacheClient
Get Context.
getContext() - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
getContext() - Method in interface alluxio.jnifuse.FuseFileSystem
 
getContext() - Method in class alluxio.master.transport.GrpcMessagingThread
 
getContext(Class<?>) - Method in class alluxio.web.JacksonProtobufObjectMapperProvider
 
getContext() - Method in class alluxio.worker.s3.S3NettyHandler
Get the channel context of this request.
getContinuationToken() - Method in class alluxio.s3.ListBucketOptions
 
getContinuationToken() - Method in class alluxio.s3.ListBucketResult
 
getContinuationToken() - Method in class alluxio.underfs.UfsLoadResult
 
getCoordinator(long) - Method in class alluxio.master.job.plan.PlanTracker
Gets a PlanCoordinator associated with the given job Id.
getCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
getCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
getCopyJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
getCopyJobBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
getCopyJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
getCopyJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
getCopyJobOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
getCopyMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getCount() - Method in class alluxio.grpc.StatusSummary.Builder
optional int64 count = 2;
getCount() - Method in class alluxio.grpc.StatusSummary
optional int64 count = 2;
getCount() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
optional int64 count = 2;
getCount() - Method in class alluxio.job.wire.StatusSummary
Returns the count of the number of jobs associated with Status.
getCounter() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getCounter() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getCounter() - Method in class alluxio.worker.netty.ReadRequestContext
 
getCounter() - Method in class alluxio.worker.netty.WriteRequestContext
 
getCounters() - Method in class alluxio.util.BucketCounter
 
getCpuLoadAverage() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
Returns the system load average of the worker.
getCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional bool createAncestors = 2;
getCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions
optional bool createAncestors = 2;
getCreateAncestors() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional bool createAncestors = 2;
getCreatedAt() - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 created_at = 3;
getCreatedAt() - Method in class alluxio.grpc.PolicyInfo
optional int64 created_at = 3;
getCreatedAt() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional int64 created_at = 3;
getCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 created_at = 3;
getCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional int64 created_at = 3;
getCreatedAt() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional int64 created_at = 3;
getCreateDirectoryMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getCreateDirectoryMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getCreatedTimestamp() - Method in class alluxio.client.file.cache.PageInfo
 
getCreateFileMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getCreateFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getCreateOptions() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
getCreateOptions() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
getCreateParent() - Method in class alluxio.underfs.options.CreateOptions
 
getCreateParent() - Method in class alluxio.underfs.options.MkdirsOptions
 
getCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
getCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand
Cancel, close and error will be handled by standard gRPC stream APIs.
getCreateUfsFileOptions() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
Cancel, close and error will be handled by standard gRPC stream APIs.
getCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
getCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
This is only applicable for ufs writes.
getCreateUfsFileOptions() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
This is only applicable for ufs writes.
getCreateUfsFileOptions() - Method in class alluxio.worker.grpc.UfsFileWriteRequest
 
getCreateUfsFileOptions() - Method in class alluxio.worker.netty.UfsFileWriteRequest
 
getCreateUfsFileOptionsBuilder() - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
getCreateUfsFileOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.grpc.WriteRequestCommand
Cancel, close and error will be handled by standard gRPC stream APIs.
getCreateUfsFileOptionsOrBuilder() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
Cancel, close and error will be handled by standard gRPC stream APIs.
getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
getCreateUfsFileOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
This is only applicable for ufs writes.
getCreateUfsFileOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
This is only applicable for ufs writes.
getCreationDate() - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
 
getCreationTime() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Returns the job creation time.
getCreationTime() - Method in class alluxio.util.webui.UIFileInfo
Gets creation time.
getCreationTimeMs() - Method in class alluxio.client.file.URIStatus
 
getCreationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 creationTimeMs = 7;
getCreationTimeMs() - Method in class alluxio.grpc.FileInfo
optional int64 creationTimeMs = 7;
getCreationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 creationTimeMs = 7;
getCreationTimeMs() - Method in class alluxio.master.file.meta.Inode
 
getCreationTimeMs() - Method in interface alluxio.master.file.meta.InodeView
 
getCreationTimeMs() - Method in class alluxio.master.file.meta.MutableInode
 
getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 creation_time_ms = 6;
getCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 creation_time_ms = 2;
getCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 creation_time_ms = 2;
getCreationTimeMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 creation_time_ms = 2;
getCreationTimeMs() - Method in class alluxio.wire.FileInfo
 
getCredentials() - Static method in class alluxio.conf.CredentialPropertyKeys
return CREDENTIAL set.
getCredentialScope() - Method in class alluxio.s3.signature.SignatureInfo
 
getCurrentBlockCount() - Method in class alluxio.master.job.LoadJob
Get the processed block count in the current loading pass.
getCurrentBlocks(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocks(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocks(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksList() - Method in class alluxio.grpc.RegisterWorkerPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest
Deprecated.
getCurrentBlocksOnTiers() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
Deprecated.
getCurrentBlocksOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
getCurrentBlocksOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getCurrentBlocksOnTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersOrDefault(String, TierList) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOnTiersOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
getCurrentBlocksOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksOrBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksOrBuilder(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksOrBuilderList() - Method in class alluxio.grpc.RegisterWorkerPRequest
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentBlocksOrBuilderList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
getCurrentDirectory() - Method in class alluxio.wire.MasterWebUIBrowse
Gets current directory.
getCurrentGroup() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
getCurrentLog(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalSnapshot
Gets the current log (the incomplete log) that is being written to.
getCurrentLog() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getCurrentMs() - Static method in class alluxio.util.CommonUtils
 
getCurrentPath() - Method in class alluxio.wire.MasterWebUIBrowse
Gets current path.
getCurrentPath() - Method in class alluxio.wire.MasterWebUILogs
Gets current path.
getCurrentPath() - Method in class alluxio.wire.WorkerWebUILogs
Gets current path.
getCurrentSequenceNumbers() - Method in interface alluxio.master.journal.JournalSystem
Used to get the current state from a leader journal system.
getCurrentSequenceNumbers() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
getCurrentSequenceNumbers() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
getCurrentSequenceNumbers() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
getCurrentStatus() - Method in class alluxio.master.backup.BackupTracker
 
getCurrentThreadIdentifier() - Static method in class alluxio.util.ThreadUtils
 
getCustomProvider() - Method in class alluxio.security.authentication.plain.CustomAuthenticationProvider
 
getData() - Method in class alluxio.grpc.Chunk.Builder
optional bytes data = 1;
getData() - Method in class alluxio.grpc.Chunk
optional bytes data = 1;
getData() - Method in interface alluxio.grpc.ChunkOrBuilder
optional bytes data = 1;
getData(int) - Method in class alluxio.grpc.Command.Builder
repeated int64 data = 2;
getData(int) - Method in class alluxio.grpc.Command
repeated int64 data = 2;
getData(int) - Method in interface alluxio.grpc.CommandOrBuilder
repeated int64 data = 2;
getData() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated. 
getData() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated. 
getData() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
Deprecated. 
getData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
getData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
getData() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
getData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated. 
getData() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated. 
getData() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
Deprecated. 
getData() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
getDatabase() - Method in class alluxio.client.hive.HiveCacheContext
 
getDatabase(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getDatabase(String) - Method in interface alluxio.client.table.TableMasterClient
Get database metadata.
getDatabase(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
getDatabase(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
repeated string database = 1;
getDatabase(int) - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
repeated string database = 1;
getDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
optional string database = 1;
getDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest
optional string database = 1;
getDatabase() - Method in interface alluxio.grpc.table.GetAllTablesPRequestOrBuilder
optional string database = 1;
getDatabase(GetDatabasePRequest, StreamObserver<GetDatabasePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Gets a database by name from the table master
getDatabase(GetDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Gets a database by name from the table master
getDatabase(GetDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Gets a database by name from the table master
getDatabase(GetDatabasePRequest, StreamObserver<GetDatabasePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Gets a database by name from the table master
getDatabaseBytes(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
getDatabaseBytes(int) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
repeated string database = 1;
getDatabaseBytes(int) - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
repeated string database = 1;
getDatabaseBytes() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
optional string database = 1;
getDatabaseBytes() - Method in class alluxio.grpc.table.GetAllTablesPRequest
optional string database = 1;
getDatabaseBytes() - Method in interface alluxio.grpc.table.GetAllTablesPRequestOrBuilder
optional string database = 1;
getDatabaseCount() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
getDatabaseCount() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
repeated string database = 1;
getDatabaseCount() - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
repeated string database = 1;
getDatabaseList() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
getDatabaseList() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
repeated string database = 1;
getDatabaseList() - Method in interface alluxio.grpc.table.GetAllDatabasesPResponseOrBuilder
repeated string database = 1;
GetDatabasePRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetDatabasePRequest
GetDatabasePRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetDatabasePRequest
GetDatabasePRequestOrBuilder - Interface in alluxio.grpc.table
 
GetDatabasePResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetDatabasePResponse
GetDatabasePResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetDatabasePResponse
GetDatabasePResponseOrBuilder - Interface in alluxio.grpc.table
 
getDataBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getDataBindHost() - Method in interface alluxio.worker.WorkerProcess
 
getDataBuffer(Channel, long, int) - Method in interface alluxio.worker.netty.AbstractReadHandler.PacketReader
Returns the appropriate DataBuffer representing the data to send, depending on the configurable transfer type.
getDataBuffer(Channel, long, int) - Method in class alluxio.worker.netty.FileReadHandler.FilePacketReader
 
getDataBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
getDataBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
getDataBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
getDataCacheDirs() - Method in class alluxio.fuse.options.MountOptions
 
getDataCacheSizes() - Method in class alluxio.fuse.options.MountOptions
 
getDataCase() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
getDataCase() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
getDataCase() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
 
getDataCols(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataCols(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataCols(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsBuilderList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsCount() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsList() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsOrBuilder(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataColsOrBuilderList() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
getDataCount() - Method in class alluxio.grpc.Command.Builder
repeated int64 data = 2;
getDataCount() - Method in class alluxio.grpc.Command
repeated int64 data = 2;
getDataCount() - Method in interface alluxio.grpc.CommandOrBuilder
repeated int64 data = 2;
getDataDomainSocketPath() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getDataDomainSocketPath() - Method in interface alluxio.worker.WorkerProcess
 
getDataFileChannel(PageId, int, int, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
Get a DataFileChannel which wraps a FileRegion.
getDataFileChannel(PageId, int, int, CacheContext) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getDataFileChannel(PageId, int, int, CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
 
getDataFileChannel(long, int) - Method in class alluxio.client.file.cache.LocalCachePositionReader
Get a DataFileChannel which wraps a FileRegion.
getDataFileChannel(PageId, int, int, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
getDataFileChannel(PageId, int, int, boolean) - Method in interface alluxio.client.file.cache.PageStore
Get a DataFileChannel which wraps a FileRegion.
getDataFileChannel(PageId, int, int, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
getDataFileChannel(PageId, int, int, boolean) - Method in class alluxio.client.file.cache.TimeBoundPageStore
 
getDataList() - Method in class alluxio.grpc.Command.Builder
repeated int64 data = 2;
getDataList() - Method in class alluxio.grpc.Command
repeated int64 data = 2;
getDataList() - Method in interface alluxio.grpc.CommandOrBuilder
repeated int64 data = 2;
getDataLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getDataLocalPort() - Method in interface alluxio.worker.WorkerProcess
 
getDataOrBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
getDataOrBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
getDataOrBuilder() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
Deprecated.
getDataOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
getDataOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
getDataOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
getDataOrBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
getDataOrBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
getDataOrBuilder() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
Deprecated.
getDataPoints() - Method in class alluxio.metrics.TimeSeries
 
getDataPoints() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getDataPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 dataPort = 3;
getDataPort() - Method in class alluxio.grpc.WorkerNetAddress
optional int32 dataPort = 3;
getDataPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional int32 dataPort = 3;
getDataPort() - Method in class alluxio.wire.WorkerNetAddress
 
getDataPortSocketAddress(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Extracts dataPort socket address from Alluxio representation of network address.
getDate() - Method in class alluxio.s3.signature.AwsCredential
 
getDate() - Method in class alluxio.s3.signature.SignatureInfo
 
getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
getDateTime() - Method in class alluxio.s3.signature.SignatureInfo
 
getDaysSinceEpoch() - Method in class alluxio.grpc.table.Date.Builder
required int64 days_since_epoch = 1;
getDaysSinceEpoch() - Method in class alluxio.grpc.table.Date
required int64 days_since_epoch = 1;
getDaysSinceEpoch() - Method in interface alluxio.grpc.table.DateOrBuilder
required int64 days_since_epoch = 1;
getDb() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
getDb() - Method in class alluxio.grpc.table.GetDatabasePResponse
optional .alluxio.grpc.table.Database db = 1;
getDb() - Method in interface alluxio.grpc.table.GetDatabasePResponseOrBuilder
optional .alluxio.grpc.table.Database db = 1;
getDb() - Method in class alluxio.rocks.RocksStore
Requires the caller to acquire a shared lock by calling RocksStore.checkAndAcquireSharedLock().
getDbBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
getDBInodeColumn() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
A testing only method to access the internal objects.
getDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string db_name = 4;
getDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string db_name = 4;
getDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string db_name = 4;
getDbName() - Method in class alluxio.grpc.table.Database.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.Database
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.DetachDatabasePRequestOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.GetDatabasePRequestOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.GetTablePRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string db_name = 3;
getDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional string db_name = 3;
getDbName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional string db_name = 3;
getDbName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.ReadTablePRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.SyncDatabasePRequestOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.TableInfo
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.TransformJobInfo
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string db_name = 1;
getDbName() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string db_name = 1;
getDbName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string db_name = 4;
getDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string db_name = 4;
getDbNameBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string db_name = 4;
getDbNameBytes() - Method in class alluxio.grpc.table.Database.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.Database
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.DetachDatabasePRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.DetachDatabasePRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetDatabasePRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.GetDatabasePRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string db_name = 3;
getDbNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional string db_name = 3;
getDbNameBytes() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional string db_name = 3;
getDbNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.SyncDatabasePRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.SyncDatabasePRequestOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.TableInfo
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string db_name = 1;
getDbNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string db_name = 1;
getDbNameBytes() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string db_name = 1;
getDbOrBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
getDbOrBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse
optional .alluxio.grpc.table.Database db = 1;
getDbOrBuilder() - Method in interface alluxio.grpc.table.GetDatabasePResponseOrBuilder
optional .alluxio.grpc.table.Database db = 1;
getDebug() - Method in class alluxio.wire.MasterWebUIBrowse
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIInit
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUILogs
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIMasters
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIMountTable
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIOverview
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIWorkers
Gets debug.
getDebug() - Method in class alluxio.wire.WorkerWebUIInit
Gets debug.
getDebug() - Method in class alluxio.wire.WorkerWebUILogs
Gets debug.
getDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecimalStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
getDecommissionedWorkerCount() - Method in interface alluxio.master.block.BlockMaster
 
getDecommissionedWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 decommissionedWorkerNum = 8;
getDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
optional int32 decommissionedWorkerNum = 8;
getDecommissionedWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int32 decommissionedWorkerNum = 8;
getDecommissionWorkerMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getDefaultAcl() - Method in class alluxio.client.file.URIStatus
 
getDefaultAcl() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
getDefaultAcl() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
getDefaultAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
getDefaultAcl() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
 
getDefaultACL() - Method in class alluxio.master.file.meta.Inode
 
getDefaultACL() - Method in interface alluxio.master.file.meta.InodeView
 
getDefaultACL() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
getDefaultACL() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
getDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
getDefaultAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
getDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
getDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
getDefaultAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
getDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
getDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
getDefaultAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
getDefaultAcl() - Method in class alluxio.wire.FileInfo
 
getDefaultAclBuilder() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
getDefaultAclBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
getDefaultAclBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
getDefaultAclBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
getDefaultAclOrBuilder() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
getDefaultAclOrBuilder() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
getDefaultAclOrBuilder() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
getDefaultAclOrBuilder() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
getDefaultAclOrBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
getDefaultAclOrBuilder() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
getDefaultAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
getDefaultAclOrBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
getDefaultAclOrBuilder() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
getDefaultBlockSize() - Method in class alluxio.hadoop.AbstractFileSystem
 
getDefaultInstance() - Static method in class alluxio.grpc.ActionInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.AddPolicyPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.AddPolicyPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.AddPolicyPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.AddQuorumServerRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.AsyncCacheRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.AsyncCacheResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.BackupPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.BackupPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.BackupPStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.BackupStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.Block
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockIdList
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockLocation
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockMasterInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.BlockStoreLocationProto
 
getDefaultInstance() - Static method in class alluxio.grpc.BuildVersion
 
getDefaultInstance() - Static method in class alluxio.grpc.CacheRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CacheResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CancelPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CancelPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CancelPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CancelTaskCommand
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckAccessPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckpointPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckpointPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CheckResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.Chunk
 
getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ClearMetricsResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ClientMetrics
 
getDefaultInstance() - Static method in class alluxio.grpc.CmdProgress
 
getDefaultInstance() - Static method in class alluxio.grpc.CmdStatusBlock
 
getDefaultInstance() - Static method in class alluxio.grpc.CmdSummary
 
getDefaultInstance() - Static method in class alluxio.grpc.Command
 
getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CommitBlockPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CompleteFilePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CompleteFilePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CompleteFilePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ConfigCheckReport
 
getDefaultInstance() - Static method in class alluxio.grpc.ConfigProperties
 
getDefaultInstance() - Static method in class alluxio.grpc.ConfigProperty
 
getDefaultInstance() - Static method in class alluxio.grpc.CopyJobPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CopyRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CopyResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.CreateFilePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.CreateFilePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.CreateFilePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.DeletePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.DeletePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.DeletePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.ErrorInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.ExistsPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ExistsPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ExistsPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.File
 
getDefaultInstance() - Static method in class alluxio.grpc.FileBlockInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.FileFailure
 
getDefaultInstance() - Static method in class alluxio.grpc.FileInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.FileSystemCommand
 
getDefaultInstance() - Static method in class alluxio.grpc.FileSystemCommandOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.FreePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.FreePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.FreePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.FreeWorkerRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.FreeWorkerResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.FsOpPId
 
getDefaultInstance() - Static method in class alluxio.grpc.GetActionInfoOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetActionInfoRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetActionInfoResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetCmdStatusResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetConfigHashPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetConfigHashPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetConfigReportPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetConfigReportPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetConfigurationPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetConfigurationPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetFileInfoPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetFileInfoPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetFileInfoPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetFilePathPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetFilePathPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobProgressPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobProgressPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetJobStatusPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMasterIdPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMetricsPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMetricsPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMountIdPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMountIdPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMountTablePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetMountTablePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetNodeStatePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetNodeStatePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetStatusPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.InconsistentProperties
 
getDefaultInstance() - Static method in class alluxio.grpc.InconsistentProperty
 
getDefaultInstance() - Static method in class alluxio.grpc.InconsistentPropertyValues
 
getDefaultInstance() - Static method in class alluxio.grpc.JobCommand
 
getDefaultInstance() - Static method in class alluxio.grpc.JobDescription
 
getDefaultInstance() - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.JobInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.JobMasterStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.JobProgress
 
getDefaultInstance() - Static method in class alluxio.grpc.JobProgressPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.JobServiceSummary
 
getDefaultInstance() - Static method in class alluxio.grpc.JobStatusBlock
 
getDefaultInstance() - Static method in class alluxio.grpc.JobUnused
 
getDefaultInstance() - Static method in class alluxio.grpc.JobWorkerHealth
 
getDefaultInstance() - Static method in class alluxio.grpc.JournalQueryRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ListAllPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ListAllPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ListAllPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ListPolicyPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ListPolicyPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ListPolicyPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ListStatusPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadFileFailure
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadFileRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadFileResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadJobPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadMetadataPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.LoadResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
getDefaultInstance() - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.MasterInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.MasterVersion
 
getDefaultInstance() - Static method in class alluxio.grpc.MessagingRequestHeader
 
getDefaultInstance() - Static method in class alluxio.grpc.MessagingResponseHeader
 
getDefaultInstance() - Static method in class alluxio.grpc.Metric
 
getDefaultInstance() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.MetricValue
 
getDefaultInstance() - Static method in class alluxio.grpc.MountPointInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.MountPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.MountPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.MountPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.MoveBlockRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.MoveBlockResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.MoveJobPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.MoveRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.MoveResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.NeedsSyncRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.NeedsSyncResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.NetAddress
 
getDefaultInstance() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.OpenFilePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.PAcl
 
getDefaultInstance() - Static method in class alluxio.grpc.PAclEntry
 
getDefaultInstance() - Static method in class alluxio.grpc.PersistCommandOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.PersistFile
 
getDefaultInstance() - Static method in class alluxio.grpc.PMode
 
getDefaultInstance() - Static method in class alluxio.grpc.PolicyInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.PolicyStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ProxyStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.QuorumServerInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.ReadRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ReadResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterCommand
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterMasterPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterMasterPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterMasterPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RemoveBlockRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RemoveBlockResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePolicyPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePolicyPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RemovePolicyPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RenamePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RenamePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RenamePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RetryInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.ReverseResolvePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ReverseResolvePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.Route
 
getDefaultInstance() - Static method in class alluxio.grpc.RouteFailure
 
getDefaultInstance() - Static method in class alluxio.grpc.RunPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.RunPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.RunPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.RunTaskCommand
 
getDefaultInstance() - Static method in class alluxio.grpc.S3SyntaxOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.SaslMessage
 
getDefaultInstance() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.SetAclPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.SetAclPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.SetAclPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.SetAttributePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.SetAttributePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.SetAttributePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
getDefaultInstance() - Static method in class alluxio.grpc.SnapshotData
 
getDefaultInstance() - Static method in class alluxio.grpc.SnapshotMetadata
 
getDefaultInstance() - Static method in class alluxio.grpc.StatusSummary
 
getDefaultInstance() - Static method in class alluxio.grpc.StopJobPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.StopJobPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.StorageList
 
getDefaultInstance() - Static method in class alluxio.grpc.SubmitJobPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.SubmitJobPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.SubmitOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.SubmitRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.SubmitResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.AllOrNoneSet
 
getDefaultInstance() - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Constraint
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Database
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Date
 
getDefaultInstance() - Static method in class alluxio.grpc.table.DateColumnStatsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Decimal
 
getDefaultInstance() - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Domain
 
getDefaultInstance() - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.EquatableValueSet
 
getDefaultInstance() - Static method in class alluxio.grpc.table.FieldSchema
 
getDefaultInstance() - Static method in class alluxio.grpc.table.FileStatistics
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetTablePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetTablePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Layout
 
getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.Storage
 
getDefaultInstance() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
getDefaultInstance() - Static method in class alluxio.grpc.table.LayoutSpec
 
getDefaultInstance() - Static method in class alluxio.grpc.table.LongColumnStatsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Partition
 
getDefaultInstance() - Static method in class alluxio.grpc.table.PartitionSpec
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Range
 
getDefaultInstance() - Static method in class alluxio.grpc.table.RangeSet
 
getDefaultInstance() - Static method in class alluxio.grpc.table.ReadTablePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.ReadTablePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Schema
 
getDefaultInstance() - Static method in class alluxio.grpc.table.StringColumnStatsData
 
getDefaultInstance() - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.SyncStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.table.TableInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Transformation
 
getDefaultInstance() - Static method in class alluxio.grpc.table.TransformJobInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.table.TransformTablePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.table.TransformTablePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.table.Value
 
getDefaultInstance() - Static method in class alluxio.grpc.TierList
 
getDefaultInstance() - Static method in class alluxio.grpc.TransferLeaderMessage
 
getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.TransportMessage
 
getDefaultInstance() - Static method in class alluxio.grpc.TriggerPolicyRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.TriggerPolicyResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.UfsFileStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.UfsInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.UfsReadOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.UfsStatus
 
getDefaultInstance() - Static method in class alluxio.grpc.UnmountPOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.UnmountPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.UnmountPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.UpdateMountPRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.UpdateMountPResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
getDefaultInstance() - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
getDefaultInstance() - Static method in class alluxio.grpc.WorkerIdentity
 
getDefaultInstance() - Static method in class alluxio.grpc.WorkerInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
getDefaultInstance() - Static method in class alluxio.grpc.WorkerNetAddress
 
getDefaultInstance() - Static method in class alluxio.grpc.WriteOptions
 
getDefaultInstance() - Static method in class alluxio.grpc.WriteRequest
 
getDefaultInstance() - Static method in class alluxio.grpc.WriteRequestCommand
 
getDefaultInstance() - Static method in class alluxio.grpc.WriteResponse
 
getDefaultInstance() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
getDefaultInstance() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
getDefaultInstance() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.RenameEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.SetAclEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.StringPairEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Job.FileFilter
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
getDefaultInstance() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
getDefaultInstance() - Static method in class alluxio.proto.meta.Block.BlockLocation
 
getDefaultInstance() - Static method in class alluxio.proto.meta.Block.BlockMeta
 
getDefaultInstance() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
getDefaultInstance() - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.AclActions
 
getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.AclEntry
 
getDefaultInstance() - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ActionInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ActionInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddPolicyPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AddQuorumServerRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.AsyncCacheResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupPStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BackupStatusPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Block.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Block
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockIdList.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockIdList
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockLocation.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockLocation
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockMasterInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BlockStoreLocationProto
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BuildVersion.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.BuildVersion
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CacheRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CacheRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CacheResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CacheResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CancelTaskCommand
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckAccessPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckpointPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CheckResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Chunk.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Chunk
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClearMetricsResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClientMetrics.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ClientMetrics
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CmdProgress.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CmdProgress
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CmdStatusBlock
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CmdSummary.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CmdSummary
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Command.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Command
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CommitBlockPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CompleteFilePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigCheckReport
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperties.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperties
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperty.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ConfigProperty
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CopyJobPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CopyRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CopyRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CopyResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CopyResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.CreateFilePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DeletePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ErrorInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ErrorInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ExistsPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.File.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.File
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileBlockInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileFailure.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileFailure
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommand
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemCommandOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FreeWorkerResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FsOpPId.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.FsOpPId
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetActionInfoResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetCmdStatusResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigHashPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigReportPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetConfigurationPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFileInfoPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetFilePathPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobProgressPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetJobStatusPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterIdPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMetricsPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountIdPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetMountTablePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetNodeStatePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetStatusPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperties
 
getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentProperty
 
getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.InconsistentPropertyValues
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobCommand.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobCommand
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobDescription.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobDescription
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobMasterStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgress.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgress
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobProgressPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobServiceSummary
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobStatusBlock
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobUnused.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobUnused
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JobWorkerHealth
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListAllPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListPolicyPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ListStatusPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileFailure
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadFileResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadJobPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LoadResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterVersion.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MasterVersion
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingRequestHeader
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MessagingResponseHeader
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Metric.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Metric
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricValue.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MetricValue
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPointInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPointInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MountPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveBlockResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveJobPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.MoveResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NeedsSyncResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NetAddress.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NetAddress
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.OpenFilePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PAcl.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PAcl
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PAclEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PAclEntry
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PersistCommandOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PersistFile.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PersistFile
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PMode.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PMode
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.PolicyStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ProxyStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.QuorumServerInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReadRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReadRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReadResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReadResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterCommand.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterCommand
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterMasterPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveBlockResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemovePolicyPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RenamePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RetryInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RetryInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ReverseResolvePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Route.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.Route
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RouteFailure.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RouteFailure
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.RunTaskCommand
 
getDefaultInstanceForType() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.S3SyntaxOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SaslMessage.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SaslMessage
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAclPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetAttributePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SnapshotMetadata
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StatusSummary.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StatusSummary
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StopJobPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StorageList.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.StorageList
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitJobPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.SubmitResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.AllOrNoneSet
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Constraint.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Constraint
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Database.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Database
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Date.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Date
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DateColumnStatsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Decimal.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Decimal
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Domain.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Domain
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.EquatableValueSet
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.FieldSchema
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.FileStatistics
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTablePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Layout.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Layout
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.Storage
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.LayoutSpec
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.LongColumnStatsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Partition.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Partition
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.PartitionSpec
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Range.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Range
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.RangeSet.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.RangeSet
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.ReadTablePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Schema.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Schema
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.StringColumnStatsData
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.SyncStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TableInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TableInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Transformation.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Transformation
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformJobInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.TransformTablePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Value.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.table.Value
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TierList.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TierList
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeaderMessage
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TransportMessage
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.TriggerPolicyResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsFileStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsReadOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UfsStatus
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UnmountPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateMountPResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerIdentity
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WorkerNetAddress
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteOptions
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequest
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteRequestCommand
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.grpc.WriteResponse
 
getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.RenameEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAclEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.StringPairEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.FileFilter
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockLocation
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.Block.BlockMeta
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclActions
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.AclEntry
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
getDefaultInstanceForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
getDefaultPort() - Method in class alluxio.hadoop.AbstractFileSystem
 
getDefaultPort() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the default port number on service.
getDefaultPort() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the default port number on service.
getDefaultReplication() - Method in class alluxio.hadoop.AbstractFileSystem
 
getDefaultSupplier() - Method in class alluxio.conf.PropertyKey
 
getDefaultValue() - Method in class alluxio.conf.PropertyKey
 
getDefinition() - Method in class alluxio.grpc.table.Transformation.Builder
optional string definition = 2;
getDefinition() - Method in class alluxio.grpc.table.Transformation
optional string definition = 2;
getDefinition() - Method in interface alluxio.grpc.table.TransformationOrBuilder
optional string definition = 2;
getDefinition() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string definition = 3;
getDefinition() - Method in class alluxio.grpc.table.TransformJobInfo
optional string definition = 3;
getDefinition() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string definition = 3;
getDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string definition = 3;
getDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string definition = 3;
getDefinition() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string definition = 3;
getDefinitionBytes() - Method in class alluxio.grpc.table.Transformation.Builder
optional string definition = 2;
getDefinitionBytes() - Method in class alluxio.grpc.table.Transformation
optional string definition = 2;
getDefinitionBytes() - Method in interface alluxio.grpc.table.TransformationOrBuilder
optional string definition = 2;
getDefinitionBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string definition = 3;
getDefinitionBytes() - Method in class alluxio.grpc.table.TransformJobInfo
optional string definition = 3;
getDefinitionBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string definition = 3;
getDefinitionBytes() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string definition = 3;
getDefinitionBytes() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string definition = 3;
getDefinitionBytes() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string definition = 3;
getDelay() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
 
getDelegate() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getDelegate() - Method in class alluxio.master.file.meta.InodeTree
 
getDelegate() - Method in class alluxio.master.file.meta.MountTable
 
getDelegate() - Method in interface alluxio.master.journal.DelegatingJournaled
 
getDelegate() - Method in class alluxio.master.meta.PathProperties
 
getDelegate() - Method in class alluxio.underfs.MasterUfsManager
 
getDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
getDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
getDeleteBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
getDeleteBlockBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
getDeleteBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
getDeleteBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
getDeleteBlockOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
getDeleted() - Method in class alluxio.s3.DeleteObjectsResult
 
getDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
getDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
getDeleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
getDeleteFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
getDeleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
getDeleteFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
getDeleteFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
getDeleteMarker() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
 
getDeleteMarkerVersionId() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
 
getDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool deleteMountPoint = 6;
getDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions
optional bool deleteMountPoint = 6;
getDeleteMountPoint() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool deleteMountPoint = 6;
getDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
getDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
getDeleteMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
getDeleteMountPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
getDeleteMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
getDeleteMountPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
getDeleteMountPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
getDelimiter() - Method in class alluxio.conf.PropertyKey
 
getDelimiter() - Method in class alluxio.s3.ListBucketOptions
 
getDelimiter() - Method in class alluxio.s3.ListBucketResult
 
getDependencies() - Method in class alluxio.master.AbstractMaster
 
getDependencies() - Method in class alluxio.master.block.DefaultBlockMaster
 
getDependencies() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getDependencies() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getDependencies() - Method in class alluxio.master.NoopMaster
 
getDependencies() - Method in interface alluxio.Server
 
getDependencies() - Method in class alluxio.worker.dora.PagedDoraWorker
 
getDependencies() - Method in class alluxio.worker.JobWorker
 
getDeployMode() - Method in class alluxio.multi.process.MultiProcessCluster
 
getDeprecationMessage(PropertyKey) - Static method in class alluxio.conf.PropertyKey
 
getDepth() - Method in class alluxio.AlluxioURI
Returns the number of elements of the path component of the AlluxioURI.
getDesc() - Method in class alluxio.cli.ValidationTaskResult
 
getDescendants(LockedInodePath) - Method in class alluxio.master.file.meta.InodeTree
Returns LockedInodePaths for all descendants of inodePath.
getDescription() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
 
getDescription() - Method in class alluxio.cli.bundler.command.CollectConfigCommand
 
getDescription() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
 
getDescription() - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
 
getDescription() - Method in class alluxio.cli.bundler.command.CollectLogCommand
 
getDescription() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
 
getDescription() - Method in interface alluxio.cli.Command
 
getDescription() - Method in class alluxio.cli.command.metadatacache.DropAllCommand
 
getDescription() - Method in class alluxio.cli.command.metadatacache.DropCommand
 
getDescription() - Method in class alluxio.cli.command.metadatacache.SizeCommand
 
getDescription() - Method in class alluxio.cli.command.MetadataCacheCommand
 
getDescription() - Method in class alluxio.cli.extensions.command.InstallCommand
 
getDescription() - Method in class alluxio.cli.extensions.command.LsCommand
 
getDescription() - Method in class alluxio.cli.extensions.command.UninstallCommand
 
getDescription() - Method in class alluxio.cli.fs.command.CatCommand
 
getDescription() - Method in class alluxio.cli.fs.command.CheckCachedCommand
 
getDescription() - Method in class alluxio.cli.fs.command.ChecksumCommand
 
getDescription() - Method in class alluxio.cli.fs.command.ChgrpCommand
 
getDescription() - Method in class alluxio.cli.fs.command.ChmodCommand
 
getDescription() - Method in class alluxio.cli.fs.command.ChownCommand
 
getDescription() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
 
getDescription() - Method in class alluxio.cli.fs.command.CpCommand
 
getDescription() - Method in class alluxio.cli.fs.command.FreeCommand
 
getDescription() - Method in class alluxio.cli.fs.command.HeadCommand
 
getDescription() - Method in class alluxio.cli.fs.command.HelpCommand
 
getDescription() - Method in class alluxio.cli.fs.command.LoadCommand
 
getDescription() - Method in class alluxio.cli.fs.command.LocationCommand
 
getDescription() - Method in class alluxio.cli.fs.command.LsCommand
 
getDescription() - Method in class alluxio.cli.fs.command.MkdirCommand
 
getDescription() - Method in class alluxio.cli.fs.command.MvCommand
 
getDescription() - Method in class alluxio.cli.fs.command.RmCommand
 
getDescription() - Method in class alluxio.cli.fs.command.StatCommand
 
getDescription() - Method in class alluxio.cli.fs.command.TailCommand
 
getDescription() - Method in class alluxio.cli.fs.command.TestCommand
 
getDescription() - Method in class alluxio.cli.fs.command.TouchCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.JournalCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.NodesCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
getDescription() - Method in class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
 
getDescription() - Method in class alluxio.cli.ValidateEnv
Gets the task descriptions.
getDescription() - Method in class alluxio.conf.PropertyKey
 
getDescription() - Method in class alluxio.DefaultSupplier
 
getDescription() - Method in class alluxio.grpc.JobInfo.Builder
optional string description = 13;
getDescription() - Method in class alluxio.grpc.JobInfo
optional string description = 13;
getDescription() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string description = 13;
getDescription() - Method in class alluxio.grpc.table.Database.Builder
optional string description = 2;
getDescription() - Method in class alluxio.grpc.table.Database
optional string description = 2;
getDescription() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string description = 2;
getDescription() - Method in interface alluxio.job.wire.JobInfo
 
getDescription() - Method in class alluxio.job.wire.PlanInfo
 
getDescription() - Method in class alluxio.job.wire.TaskInfo
 
getDescription() - Method in class alluxio.job.wire.WorkflowInfo
 
getDescription() - Method in class alluxio.master.job.CopyJob
 
getDescription() - Method in class alluxio.master.job.DoraLoadJob
 
getDescription() - Method in class alluxio.master.job.LoadJob
 
getDescription() - Method in class alluxio.master.job.MoveJob
 
getDescription() - Method in class alluxio.metrics.MetricKey
 
getDescription() - Method in class alluxio.s3.S3ErrorCode
 
getDescription() - Method in interface alluxio.scheduler.job.Job
 
getDescription(List<String>) - Method in class alluxio.stress.Parameters
Returns a string representation of the parameters, using only the specified fields.
getDescriptionBytes() - Method in class alluxio.grpc.JobInfo.Builder
optional string description = 13;
getDescriptionBytes() - Method in class alluxio.grpc.JobInfo
optional string description = 13;
getDescriptionBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string description = 13;
getDescriptionBytes() - Method in class alluxio.grpc.table.Database.Builder
optional string description = 2;
getDescriptionBytes() - Method in class alluxio.grpc.table.Database
optional string description = 2;
getDescriptionBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string description = 2;
getDescriptor() - Static method in class alluxio.grpc.ActionInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ActionInfo
 
getDescriptor() - Static method in class alluxio.grpc.AddPolicyPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.AddPolicyPOptions
 
getDescriptor() - Static method in class alluxio.grpc.AddPolicyPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.AddPolicyPRequest
 
getDescriptor() - Static method in class alluxio.grpc.AddPolicyPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.AddPolicyPResponse
 
getDescriptor() - Static method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.AddQuorumServerRequest
 
getDescriptor() - Static method in class alluxio.grpc.AsyncCacheRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.AsyncCacheRequest
 
getDescriptor() - Static method in class alluxio.grpc.AsyncCacheResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.AsyncCacheResponse
 
getDescriptor() - Static method in class alluxio.grpc.AuthenticationServerProto
 
getDescriptor() - Static method in class alluxio.grpc.BackupPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BackupPOptions
 
getDescriptor() - Static method in class alluxio.grpc.BackupPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BackupPRequest
 
getDescriptor() - Static method in class alluxio.grpc.BackupPStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BackupPStatus
 
getDescriptor() - Static method in enum alluxio.grpc.BackupState
 
getDescriptor() - Static method in class alluxio.grpc.BackupStatusPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BackupStatusPRequest
 
getDescriptor() - Static method in enum alluxio.grpc.Bits
 
getDescriptor() - Static method in class alluxio.grpc.Block.Builder
 
getDescriptor() - Static method in class alluxio.grpc.Block
 
getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
getDescriptor() - Static method in class alluxio.grpc.BlockIdList.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockIdList
 
getDescriptor() - Static method in class alluxio.grpc.BlockInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockInfo
 
getDescriptor() - Static method in class alluxio.grpc.BlockLocation.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockLocation
 
getDescriptor() - Static method in class alluxio.grpc.BlockMasterInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockMasterInfo
 
getDescriptor() - Static method in enum alluxio.grpc.BlockMasterInfoField
 
getDescriptor() - Static method in class alluxio.grpc.BlockMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.BlockStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockStatus
 
getDescriptor() - Static method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BlockStoreLocationProto
 
getDescriptor() - Static method in class alluxio.grpc.BlockWorkerProto
 
getDescriptor() - Static method in class alluxio.grpc.BuildVersion.Builder
 
getDescriptor() - Static method in class alluxio.grpc.BuildVersion
 
getDescriptor() - Static method in class alluxio.grpc.CacheRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CacheRequest
 
getDescriptor() - Static method in class alluxio.grpc.CacheResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CacheResponse
 
getDescriptor() - Static method in class alluxio.grpc.CancelPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CancelPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CancelPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CancelPRequest
 
getDescriptor() - Static method in class alluxio.grpc.CancelPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CancelPResponse
 
getDescriptor() - Static method in class alluxio.grpc.CancelTaskCommand.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CancelTaskCommand
 
getDescriptor() - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
 
getDescriptor() - Static method in class alluxio.grpc.CheckAccessPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckAccessPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CheckAccessPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckAccessPRequest
 
getDescriptor() - Static method in class alluxio.grpc.CheckAccessPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckAccessPResponse
 
getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
getDescriptor() - Static method in class alluxio.grpc.CheckpointPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckpointPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CheckpointPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckpointPResponse
 
getDescriptor() - Static method in class alluxio.grpc.CheckRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckRequest
 
getDescriptor() - Static method in class alluxio.grpc.CheckResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CheckResponse
 
getDescriptor() - Static method in class alluxio.grpc.Chunk.Builder
 
getDescriptor() - Static method in class alluxio.grpc.Chunk
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsPResponse
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsRequest
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ClearMetricsResponse
 
getDescriptor() - Static method in class alluxio.grpc.ClientMetrics.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ClientMetrics
 
getDescriptor() - Static method in class alluxio.grpc.CmdProgress.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CmdProgress
 
getDescriptor() - Static method in class alluxio.grpc.CmdStatusBlock.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CmdStatusBlock
 
getDescriptor() - Static method in class alluxio.grpc.CmdSummary.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CmdSummary
 
getDescriptor() - Static method in class alluxio.grpc.Command.Builder
 
getDescriptor() - Static method in class alluxio.grpc.Command
 
getDescriptor() - Static method in enum alluxio.grpc.CommandType
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockPRequest
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CommitBlockPResponse
 
getDescriptor() - Static method in class alluxio.grpc.CommonProto
 
getDescriptor() - Static method in class alluxio.grpc.CompleteFilePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CompleteFilePOptions
 
getDescriptor() - Static method in class alluxio.grpc.CompleteFilePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CompleteFilePRequest
 
getDescriptor() - Static method in class alluxio.grpc.CompleteFilePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CompleteFilePResponse
 
getDescriptor() - Static method in class alluxio.grpc.ConfigCheckReport.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ConfigCheckReport
 
getDescriptor() - Static method in class alluxio.grpc.ConfigProperties.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ConfigProperties
 
getDescriptor() - Static method in class alluxio.grpc.ConfigProperty.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ConfigProperty
 
getDescriptor() - Static method in enum alluxio.grpc.ConfigStatus
 
getDescriptor() - Static method in class alluxio.grpc.CopyJobPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CopyJobPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CopyRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CopyRequest
 
getDescriptor() - Static method in class alluxio.grpc.CopyResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CopyResponse
 
getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
getDescriptor() - Static method in class alluxio.grpc.CreateFilePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateFilePOptions
 
getDescriptor() - Static method in class alluxio.grpc.CreateFilePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateFilePRequest
 
getDescriptor() - Static method in class alluxio.grpc.CreateFilePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.CreateFilePResponse
 
getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
getDescriptor() - Static method in class alluxio.grpc.DeletePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.DeletePOptions
 
getDescriptor() - Static method in class alluxio.grpc.DeletePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.DeletePRequest
 
getDescriptor() - Static method in class alluxio.grpc.DeletePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.DeletePResponse
 
getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.ErrorInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ErrorInfo
 
getDescriptor() - Static method in enum alluxio.grpc.ErrorType
 
getDescriptor() - Static method in class alluxio.grpc.ExistsPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ExistsPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ExistsPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ExistsPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ExistsPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ExistsPResponse
 
getDescriptor() - Static method in class alluxio.grpc.File.Builder
 
getDescriptor() - Static method in class alluxio.grpc.File
 
getDescriptor() - Static method in class alluxio.grpc.FileBlockInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileBlockInfo
 
getDescriptor() - Static method in class alluxio.grpc.FileFailure.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileFailure
 
getDescriptor() - Static method in class alluxio.grpc.FileInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileInfo
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemCommand.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemCommand
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemCommandOptions
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
getDescriptor() - Static method in class alluxio.grpc.FileSystemMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.FreePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FreePOptions
 
getDescriptor() - Static method in class alluxio.grpc.FreePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FreePRequest
 
getDescriptor() - Static method in class alluxio.grpc.FreePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FreePResponse
 
getDescriptor() - Static method in class alluxio.grpc.FreeWorkerRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FreeWorkerRequest
 
getDescriptor() - Static method in class alluxio.grpc.FreeWorkerResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FreeWorkerResponse
 
getDescriptor() - Static method in class alluxio.grpc.FsCommonProto
 
getDescriptor() - Static method in class alluxio.grpc.FsOpPId.Builder
 
getDescriptor() - Static method in class alluxio.grpc.FsOpPId
 
getDescriptor() - Static method in class alluxio.grpc.GetActionInfoOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetActionInfoOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetActionInfoRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetActionInfoRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetActionInfoResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetActionInfoResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetCmdStatusResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigHashPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigReportPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetConfigurationPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetFileInfoPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetFilePathPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetFilePathPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetFilePathPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetFilePathPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobProgressPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetJobStatusPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterIdPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetMetricsPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMetricsPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetMetricsPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMetricsPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetMountIdPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMountIdPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetMountIdPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMountIdPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetMountTablePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMountTablePRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetMountTablePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetMountTablePResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetNodeStatePResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetStatusPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetStatusPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetStatusPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetStatusPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetStatusPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetStatusPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
getDescriptor() - Static method in class alluxio.grpc.InconsistentProperties.Builder
 
getDescriptor() - Static method in class alluxio.grpc.InconsistentProperties
 
getDescriptor() - Static method in class alluxio.grpc.InconsistentProperty.Builder
 
getDescriptor() - Static method in class alluxio.grpc.InconsistentProperty
 
getDescriptor() - Static method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
getDescriptor() - Static method in class alluxio.grpc.InconsistentPropertyValues
 
getDescriptor() - Static method in class alluxio.grpc.JobCommand.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobCommand
 
getDescriptor() - Static method in class alluxio.grpc.JobDescription.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobDescription
 
getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
getDescriptor() - Static method in class alluxio.grpc.JobInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobInfo
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
getDescriptor() - Static method in enum alluxio.grpc.JobMasterMetaCommand
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobMasterStatus
 
getDescriptor() - Static method in class alluxio.grpc.JobProgress.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobProgress
 
getDescriptor() - Static method in class alluxio.grpc.JobProgressPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobProgressPOptions
 
getDescriptor() - Static method in enum alluxio.grpc.JobProgressReportFormat
 
getDescriptor() - Static method in class alluxio.grpc.JobServiceSummary.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobServiceSummary
 
getDescriptor() - Static method in enum alluxio.grpc.JobSource
 
getDescriptor() - Static method in class alluxio.grpc.JobStatusBlock.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobStatusBlock
 
getDescriptor() - Static method in enum alluxio.grpc.JobType
 
getDescriptor() - Static method in class alluxio.grpc.JobUnused.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobUnused
 
getDescriptor() - Static method in class alluxio.grpc.JobWorkerHealth.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JobWorkerHealth
 
getDescriptor() - Static method in enum alluxio.grpc.JournalDomain
 
getDescriptor() - Static method in class alluxio.grpc.JournalMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.JournalQueryRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.JournalQueryRequest
 
getDescriptor() - Static method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ListAllPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListAllPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ListAllPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListAllPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ListAllPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListAllPResponse
 
getDescriptor() - Static method in class alluxio.grpc.ListPolicyPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListPolicyPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ListPolicyPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListPolicyPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ListPolicyPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListPolicyPResponse
 
getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ListStatusPResponse
 
getDescriptor() - Static method in enum alluxio.grpc.LoadDescendantPType
 
getDescriptor() - Static method in class alluxio.grpc.LoadFileFailure.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LoadFileFailure
 
getDescriptor() - Static method in class alluxio.grpc.LoadFileRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LoadFileRequest
 
getDescriptor() - Static method in class alluxio.grpc.LoadFileResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LoadFileResponse
 
getDescriptor() - Static method in class alluxio.grpc.LoadJobPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LoadJobPOptions
 
getDescriptor() - Static method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LoadMetadataPOptions
 
getDescriptor() - Static method in enum alluxio.grpc.LoadMetadataPType
 
getDescriptor() - Static method in class alluxio.grpc.LoadRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LoadRequest
 
getDescriptor() - Static method in class alluxio.grpc.LoadResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LoadResponse
 
getDescriptor() - Static method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
getDescriptor() - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
getDescriptor() - Static method in class alluxio.grpc.MasterInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MasterInfo
 
getDescriptor() - Static method in enum alluxio.grpc.MasterInfoField
 
getDescriptor() - Static method in class alluxio.grpc.MasterVersion.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MasterVersion
 
getDescriptor() - Static method in class alluxio.grpc.MessagingRequestHeader.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MessagingRequestHeader
 
getDescriptor() - Static method in class alluxio.grpc.MessagingResponseHeader.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MessagingResponseHeader
 
getDescriptor() - Static method in class alluxio.grpc.MessagingTransportProto
 
getDescriptor() - Static method in enum alluxio.grpc.MetaCommand
 
getDescriptor() - Static method in class alluxio.grpc.MetaMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.Metric.Builder
 
getDescriptor() - Static method in class alluxio.grpc.Metric
 
getDescriptor() - Static method in class alluxio.grpc.MetricMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
getDescriptor() - Static method in enum alluxio.grpc.MetricType
 
getDescriptor() - Static method in class alluxio.grpc.MetricValue.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MetricValue
 
getDescriptor() - Static method in class alluxio.grpc.MountPointInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MountPointInfo
 
getDescriptor() - Static method in class alluxio.grpc.MountPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MountPOptions
 
getDescriptor() - Static method in class alluxio.grpc.MountPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MountPRequest
 
getDescriptor() - Static method in class alluxio.grpc.MountPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MountPResponse
 
getDescriptor() - Static method in class alluxio.grpc.MoveBlockRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MoveBlockRequest
 
getDescriptor() - Static method in class alluxio.grpc.MoveBlockResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MoveBlockResponse
 
getDescriptor() - Static method in class alluxio.grpc.MoveJobPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MoveJobPOptions
 
getDescriptor() - Static method in class alluxio.grpc.MoveRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MoveRequest
 
getDescriptor() - Static method in class alluxio.grpc.MoveResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.MoveResponse
 
getDescriptor() - Static method in class alluxio.grpc.NeedsSyncRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.NeedsSyncRequest
 
getDescriptor() - Static method in class alluxio.grpc.NeedsSyncResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.NeedsSyncResponse
 
getDescriptor() - Static method in class alluxio.grpc.NetAddress.Builder
 
getDescriptor() - Static method in class alluxio.grpc.NetAddress
 
getDescriptor() - Static method in enum alluxio.grpc.NodeState
 
getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
getDescriptor() - Static method in class alluxio.grpc.OpenFilePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.OpenFilePOptions
 
getDescriptor() - Static method in enum alluxio.grpc.OperationType
 
getDescriptor() - Static method in class alluxio.grpc.PAcl.Builder
 
getDescriptor() - Static method in class alluxio.grpc.PAcl
 
getDescriptor() - Static method in enum alluxio.grpc.PAclAction
 
getDescriptor() - Static method in class alluxio.grpc.PAclEntry.Builder
 
getDescriptor() - Static method in class alluxio.grpc.PAclEntry
 
getDescriptor() - Static method in enum alluxio.grpc.PAclEntryType
 
getDescriptor() - Static method in class alluxio.grpc.PersistCommandOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.PersistCommandOptions
 
getDescriptor() - Static method in class alluxio.grpc.PersistFile.Builder
 
getDescriptor() - Static method in class alluxio.grpc.PersistFile
 
getDescriptor() - Static method in class alluxio.grpc.PMode.Builder
 
getDescriptor() - Static method in class alluxio.grpc.PMode
 
getDescriptor() - Static method in class alluxio.grpc.PolicyInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.PolicyInfo
 
getDescriptor() - Static method in class alluxio.grpc.PolicyMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.PolicyStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.PolicyStatus
 
getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
getDescriptor() - Static method in class alluxio.grpc.ProxyStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ProxyStatus
 
getDescriptor() - Static method in class alluxio.grpc.QuorumServerInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.QuorumServerInfo
 
getDescriptor() - Static method in enum alluxio.grpc.QuorumServerState
 
getDescriptor() - Static method in class alluxio.grpc.RaftJournalProto
 
getDescriptor() - Static method in enum alluxio.grpc.ReadPType
 
getDescriptor() - Static method in class alluxio.grpc.ReadRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ReadRequest
 
getDescriptor() - Static method in class alluxio.grpc.ReadResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ReadResponse
 
getDescriptor() - Static method in class alluxio.grpc.RegisterCommand.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterCommand
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterMasterPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RemoveBlockRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemoveBlockRequest
 
getDescriptor() - Static method in class alluxio.grpc.RemoveBlockResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemoveBlockResponse
 
getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemovePolicyPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RenamePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RenamePOptions
 
getDescriptor() - Static method in class alluxio.grpc.RenamePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RenamePRequest
 
getDescriptor() - Static method in class alluxio.grpc.RenamePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RenamePResponse
 
getDescriptor() - Static method in enum alluxio.grpc.RequestType
 
getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RetryInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RetryInfo
 
getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePRequest
 
getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ReverseResolvePResponse
 
getDescriptor() - Static method in class alluxio.grpc.Route.Builder
 
getDescriptor() - Static method in class alluxio.grpc.Route
 
getDescriptor() - Static method in class alluxio.grpc.RouteFailure.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RouteFailure
 
getDescriptor() - Static method in class alluxio.grpc.RunPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RunPOptions
 
getDescriptor() - Static method in class alluxio.grpc.RunPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RunPRequest
 
getDescriptor() - Static method in class alluxio.grpc.RunPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RunPResponse
 
getDescriptor() - Static method in class alluxio.grpc.RunTaskCommand.Builder
 
getDescriptor() - Static method in class alluxio.grpc.RunTaskCommand
 
getDescriptor() - Static method in class alluxio.grpc.S3SyntaxOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.S3SyntaxOptions
 
getDescriptor() - Static method in class alluxio.grpc.SaslMessage.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SaslMessage
 
getDescriptor() - Static method in enum alluxio.grpc.SaslMessageType
 
getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
getDescriptor() - Static method in enum alluxio.grpc.Scope
 
getDescriptor() - Static method in enum alluxio.grpc.ServiceType
 
getDescriptor() - Static method in enum alluxio.grpc.SetAclAction
 
getDescriptor() - Static method in class alluxio.grpc.SetAclPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetAclPOptions
 
getDescriptor() - Static method in class alluxio.grpc.SetAclPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetAclPRequest
 
getDescriptor() - Static method in class alluxio.grpc.SetAclPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetAclPResponse
 
getDescriptor() - Static method in class alluxio.grpc.SetAttributePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetAttributePOptions
 
getDescriptor() - Static method in class alluxio.grpc.SetAttributePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetAttributePRequest
 
getDescriptor() - Static method in class alluxio.grpc.SetAttributePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetAttributePResponse
 
getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
getDescriptor() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
getDescriptor() - Static method in class alluxio.grpc.SnapshotData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SnapshotData
 
getDescriptor() - Static method in class alluxio.grpc.SnapshotMetadata.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SnapshotMetadata
 
getDescriptor() - Static method in enum alluxio.grpc.Status
 
getDescriptor() - Static method in class alluxio.grpc.StatusSummary.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StatusSummary
 
getDescriptor() - Static method in class alluxio.grpc.StopJobPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StopJobPRequest
 
getDescriptor() - Static method in class alluxio.grpc.StopJobPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StopJobPResponse
 
getDescriptor() - Static method in class alluxio.grpc.StorageList.Builder
 
getDescriptor() - Static method in class alluxio.grpc.StorageList
 
getDescriptor() - Static method in class alluxio.grpc.SubmitJobPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SubmitJobPRequest
 
getDescriptor() - Static method in class alluxio.grpc.SubmitJobPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SubmitJobPResponse
 
getDescriptor() - Static method in class alluxio.grpc.SubmitOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SubmitOptions
 
getDescriptor() - Static method in class alluxio.grpc.SubmitRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SubmitRequest
 
getDescriptor() - Static method in class alluxio.grpc.SubmitResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.SubmitResponse
 
getDescriptor() - Static method in enum alluxio.grpc.SyncPointStatus
 
getDescriptor() - Static method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.AllOrNoneSet
 
getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
getDescriptor() - Static method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
getDescriptor() - Static method in class alluxio.grpc.table.Constraint.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Constraint
 
getDescriptor() - Static method in class alluxio.grpc.table.Database.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Database
 
getDescriptor() - Static method in class alluxio.grpc.table.Date.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Date
 
getDescriptor() - Static method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.DateColumnStatsData
 
getDescriptor() - Static method in class alluxio.grpc.table.Decimal.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Decimal
 
getDescriptor() - Static method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.Domain.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Domain
 
getDescriptor() - Static method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
getDescriptor() - Static method in class alluxio.grpc.table.EquatableValueSet.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.EquatableValueSet
 
getDescriptor() - Static method in class alluxio.grpc.table.FieldSchema.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.FieldSchema
 
getDescriptor() - Static method in class alluxio.grpc.table.FileStatistics.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.FileStatistics
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTablePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTablePRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTablePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTablePResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.Layout.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Layout
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.HiveLayoutProto
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
getDescriptor() - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.Storage
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
getDescriptor() - Static method in class alluxio.grpc.table.LayoutSpec.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.LayoutSpec
 
getDescriptor() - Static method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.LongColumnStatsData
 
getDescriptor() - Static method in class alluxio.grpc.table.Partition.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Partition
 
getDescriptor() - Static method in class alluxio.grpc.table.PartitionSpec.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.PartitionSpec
 
getDescriptor() - Static method in enum alluxio.grpc.table.PrincipalType
 
getDescriptor() - Static method in class alluxio.grpc.table.Range.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Range
 
getDescriptor() - Static method in class alluxio.grpc.table.RangeSet.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.RangeSet
 
getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.ReadTablePResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.Schema.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Schema
 
getDescriptor() - Static method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.StringColumnStatsData
 
getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.SyncStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.SyncStatus
 
getDescriptor() - Static method in class alluxio.grpc.table.TableInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.TableInfo
 
getDescriptor() - Static method in enum alluxio.grpc.table.TableInfo.TableType
 
getDescriptor() - Static method in class alluxio.grpc.table.TableMasterProto
 
getDescriptor() - Static method in class alluxio.grpc.table.Transformation.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Transformation
 
getDescriptor() - Static method in class alluxio.grpc.table.TransformJobInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.TransformJobInfo
 
getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePRequest
 
getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.TransformTablePResponse
 
getDescriptor() - Static method in class alluxio.grpc.table.Value.Builder
 
getDescriptor() - Static method in class alluxio.grpc.table.Value
 
getDescriptor() - Static method in enum alluxio.grpc.TaskStatus
 
getDescriptor() - Static method in class alluxio.grpc.TierList.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TierList
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeaderMessage.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeaderMessage
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
getDescriptor() - Static method in class alluxio.grpc.TransportMessage.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TransportMessage
 
getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyRequest
 
getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.TriggerPolicyResponse
 
getDescriptor() - Static method in enum alluxio.grpc.TtlAction
 
getDescriptor() - Static method in class alluxio.grpc.UfsFileStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UfsFileStatus
 
getDescriptor() - Static method in class alluxio.grpc.UfsInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UfsInfo
 
getDescriptor() - Static method in enum alluxio.grpc.UfsPMode
 
getDescriptor() - Static method in class alluxio.grpc.UfsReadOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UfsReadOptions
 
getDescriptor() - Static method in class alluxio.grpc.UfsStatus.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UfsStatus
 
getDescriptor() - Static method in class alluxio.grpc.UnmountPOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UnmountPOptions
 
getDescriptor() - Static method in class alluxio.grpc.UnmountPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UnmountPRequest
 
getDescriptor() - Static method in class alluxio.grpc.UnmountPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UnmountPResponse
 
getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
getDescriptor() - Static method in class alluxio.grpc.UpdateMountPRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UpdateMountPRequest
 
getDescriptor() - Static method in class alluxio.grpc.UpdateMountPResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UpdateMountPResponse
 
getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
getDescriptor() - Static method in class alluxio.grpc.VersionProto
 
getDescriptor() - Static method in class alluxio.grpc.WorkerIdentity.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WorkerIdentity
 
getDescriptor() - Static method in class alluxio.grpc.WorkerInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WorkerInfo
 
getDescriptor() - Static method in enum alluxio.grpc.WorkerInfoField
 
getDescriptor() - Static method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
getDescriptor() - Static method in class alluxio.grpc.WorkerNetAddress.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WorkerNetAddress
 
getDescriptor() - Static method in enum alluxio.grpc.WorkerRange
 
getDescriptor() - Static method in class alluxio.grpc.WriteOptions.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WriteOptions
 
getDescriptor() - Static method in enum alluxio.grpc.WritePType
 
getDescriptor() - Static method in class alluxio.grpc.WriteRequest.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WriteRequest
 
getDescriptor() - Static method in class alluxio.grpc.WriteRequestCommand.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WriteRequestCommand
 
getDescriptor() - Static method in class alluxio.grpc.WriteResponse.Builder
 
getDescriptor() - Static method in class alluxio.grpc.WriteResponse
 
getDescriptor() - Static method in enum alluxio.grpc.XAttrPropagationStrategy
 
getDescriptor() - Static method in class alluxio.proto.client.Cache
 
getDescriptor() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
getDescriptor() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getDescriptor() - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getDescriptor() - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
getDescriptor() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Block
 
getDescriptor() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
getDescriptor() - Static method in enum alluxio.proto.journal.File.PSetAclAction
 
getDescriptor() - Static method in enum alluxio.proto.journal.File.PTtlAction
 
getDescriptor() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.RenameEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.RenameEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.SetAclEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.StringPairEntry
 
getDescriptor() - Static method in enum alluxio.proto.journal.File.UfsMode
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getDescriptor() - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.FileFilter.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.FileFilter
 
getDescriptor() - Static method in class alluxio.proto.journal.Job
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
getDescriptor() - Static method in enum alluxio.proto.journal.Job.PJobState
 
getDescriptor() - Static method in class alluxio.proto.journal.Journal
 
getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
getDescriptor() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Meta
 
getDescriptor() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Policy
 
getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockLocation
 
getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
getDescriptor() - Static method in class alluxio.proto.meta.Block.BlockMeta
 
getDescriptor() - Static method in class alluxio.proto.meta.Block
 
getDescriptor() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
getDescriptor() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
getDescriptor() - Static method in class alluxio.proto.meta.DoraMeta
 
getDescriptor() - Static method in class alluxio.proto.meta.InodeMeta
 
getDescriptor() - Static method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
getDescriptor() - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
getDescriptor() - Static method in enum alluxio.proto.shared.Acl.AclAction
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclActions.Builder
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclActions
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.AclEntry
 
getDescriptor() - Static method in enum alluxio.proto.shared.Acl.AclEntryType
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
getDescriptor() - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
getDescriptor() - Static method in class alluxio.proto.status.Status
 
getDescriptor() - Static method in enum alluxio.proto.status.Status.PStatus
 
getDescriptorForType() - Method in class alluxio.grpc.ActionInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BackupPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BackupPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BackupPStatus.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.BackupState
 
getDescriptorForType() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.Bits
 
getDescriptorForType() - Method in class alluxio.grpc.Block.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockIdList.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockLocation.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.BlockMasterInfoField
 
getDescriptorForType() - Method in class alluxio.grpc.BlockStatus.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.BuildVersion.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CacheRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CacheResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CancelPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CancelPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CancelPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.ChannelAuthenticationScheme
 
getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CheckResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.Chunk.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ClientMetrics.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CmdProgress.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CmdSummary.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.Command.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.CommandType
 
getDescriptorForType() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ConfigProperties.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ConfigProperty.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.ConfigStatus
 
getDescriptorForType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CopyRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CopyResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.DeletePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.DeletePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.DeletePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.ErrorInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.ErrorType
 
getDescriptorForType() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.File.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileFailure.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FreePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FreePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FreePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.FsOpPId.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobCommand.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobDescription.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.JobMasterMetaCommand
 
getDescriptorForType() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobProgress.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.JobProgressReportFormat
 
getDescriptorForType() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.JobSource
 
getDescriptorForType() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.JobType
 
getDescriptorForType() - Method in class alluxio.grpc.JobUnused.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.JournalDomain
 
getDescriptorForType() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.LoadDescendantPType
 
getDescriptorForType() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.LoadMetadataPType
 
getDescriptorForType() - Method in class alluxio.grpc.LoadRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.LoadResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MasterInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.MasterInfoField
 
getDescriptorForType() - Method in class alluxio.grpc.MasterVersion.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.MetaCommand
 
getDescriptorForType() - Method in class alluxio.grpc.Metric.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.MetricType
 
getDescriptorForType() - Method in class alluxio.grpc.MetricValue.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MountPointInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MountPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MountPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MountPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MoveRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.MoveResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.NetAddress.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.NodeState
 
getDescriptorForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.OperationType
 
getDescriptorForType() - Method in class alluxio.grpc.PAcl.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.PAclAction
 
getDescriptorForType() - Method in class alluxio.grpc.PAclEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.PAclEntryType
 
getDescriptorForType() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.PersistFile.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.PMode.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.PolicyInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.PolicyStatus.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ProxyStatus.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.QuorumServerState
 
getDescriptorForType() - Method in enum alluxio.grpc.ReadPType
 
getDescriptorForType() - Method in class alluxio.grpc.ReadRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ReadResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterCommand.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RenamePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RenamePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RenamePResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.RequestType
 
getDescriptorForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RetryInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.Route.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RouteFailure.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RunPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RunPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RunPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SaslMessage.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.SaslMessageType
 
getDescriptorForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.Scope
 
getDescriptorForType() - Method in enum alluxio.grpc.ServiceType
 
getDescriptorForType() - Method in enum alluxio.grpc.SetAclAction
 
getDescriptorForType() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SnapshotData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.Status
 
getDescriptorForType() - Method in class alluxio.grpc.StatusSummary.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.StorageList.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SubmitOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SubmitRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.SubmitResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.SyncPointStatus
 
getDescriptorForType() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Constraint.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Database.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Date.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Decimal.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Domain.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Layout.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
 
getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Partition.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.table.PrincipalType
 
getDescriptorForType() - Method in class alluxio.grpc.table.Range.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.RangeSet.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Schema.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.TableInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.table.TableInfo.TableType
 
getDescriptorForType() - Method in class alluxio.grpc.table.Transformation.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.table.Value.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.TaskStatus
 
getDescriptorForType() - Method in class alluxio.grpc.TierList.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TransportMessage.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.TtlAction
 
getDescriptorForType() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UfsInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.UfsPMode
 
getDescriptorForType() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UfsStatus.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
getDescriptorForType() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.WorkerInfo.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.WorkerInfoField
 
getDescriptorForType() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.WorkerRange
 
getDescriptorForType() - Method in class alluxio.grpc.WriteOptions.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.WritePType
 
getDescriptorForType() - Method in class alluxio.grpc.WriteRequest.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
getDescriptorForType() - Method in class alluxio.grpc.WriteResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.grpc.XAttrPropagationStrategy
 
getDescriptorForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getDescriptorForType() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
getDescriptorForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.journal.File.PSetAclAction
 
getDescriptorForType() - Method in enum alluxio.proto.journal.File.PTtlAction
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.journal.File.UfsMode
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
 
getDescriptorForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.journal.Job.PJobState
 
getDescriptorForType() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
getDescriptorForType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
getDescriptorForType() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
getDescriptorForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
getDescriptorForType() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
getDescriptorForType() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.shared.Acl.AclAction
 
getDescriptorForType() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
getDescriptorForType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.shared.Acl.AclEntryType
 
getDescriptorForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
getDescriptorForType() - Method in enum alluxio.proto.status.Status.PStatus
 
getDesiredPattern() - Method in class alluxio.master.file.meta.LockingScheme
 
getDestination() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getDestination() - Method in class alluxio.job.plan.migrate.MigrateCommand
 
getDestination() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
getDetachDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getDetailedCmdStatus(long, JobMasterClient, Set<String>, List<String>) - Static method in class alluxio.cli.util.DistributedCommandUtil
Get detailed information about a command.
getDeviceSpec() - Method in class alluxio.util.UnixMountInfo
 
getDir() - Method in class alluxio.master.backcompat.Journal
 
getDir(int) - Method in interface alluxio.worker.block.meta.StorageTier
Returns a directory for the given index.
getDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool directChildrenLoaded = 13;
getDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions
optional bool directChildrenLoaded = 13;
getDirectChildrenLoaded() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool directChildrenLoaded = 13;
getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool direct_children_loaded = 12;
getDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool direct_children_loaded = 12;
getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool direct_children_loaded = 3;
getDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional bool direct_children_loaded = 3;
getDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional bool direct_children_loaded = 3;
getDirectMemUsed() - Static method in class alluxio.metrics.MetricsSystem
 
getDirectoryPathsOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getDirectoryStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getDirectoryStatus(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
getDirectoryStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getDirectoryStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getDirectoryStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getDirectoryStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the directory status.
getDirectoryStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getDirectoryStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting directory status.
getDirIndex() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the zero-based index of this dir in its parent StorageTier.
getDirMedium() - Method in interface alluxio.worker.block.meta.StorageDir
 
getDirPath() - Method in class alluxio.util.webui.UIStorageDir
Gets dir path.
getDirPath() - Method in interface alluxio.worker.block.meta.StorageDir
 
getDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions.Builder
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
getDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
getDisableAreDescendantsLoadedCheck() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
getDiskCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk capacity.
getDiskFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk free capacity.
getDiskInfo() - Method in class alluxio.master.meta.JournalSpaceMonitor
Gets the current disk information from the system for the journal path.
getDiskPath() - Method in class alluxio.wire.JournalDiskInfo
 
getDiskPathWithSchema() - Method in class alluxio.wire.JournalDiskInfo
 
getDiskUsedCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk used capacity.
getDisplayMountPointInfo(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getDisplayMountPointInfo(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Gets the mount point information of an Alluxio path for display purpose.
getDisplayType() - Method in class alluxio.conf.PropertyKey
 
getDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
optional .alluxio.grpc.journal.JournalDomain domain = 1;
getDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse
optional .alluxio.grpc.journal.JournalDomain domain = 1;
getDomain() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
optional .alluxio.grpc.journal.JournalDomain domain = 1;
getDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string domainSocketPath = 5;
getDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress
optional string domainSocketPath = 5;
getDomainSocketPath() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string domainSocketPath = 5;
getDomainSocketPath() - Method in class alluxio.wire.WorkerNetAddress
 
getDomainSocketPathBytes() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string domainSocketPath = 5;
getDomainSocketPathBytes() - Method in class alluxio.grpc.WorkerNetAddress
optional string domainSocketPath = 5;
getDomainSocketPathBytes() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string domainSocketPath = 5;
getDoraCacheFileSystem() - Method in class alluxio.client.file.DelegatingFileSystem
 
getDoraCacheFileSystem() - Method in class alluxio.client.file.DoraCacheFileSystem
 
getDoraCacheFileSystem() - Method in interface alluxio.client.file.FileSystem
 
getDoraCacheFileSystem() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getDoraMeta(String) - Method in interface alluxio.worker.dora.DoraMetaStore
queries dora metadata from the dora meta store.
getDoraMeta(String) - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
Queries the metadata for a file.
getDoraWorker() - Method in class alluxio.worker.s3.S3NettyHandler
Get dora worker object.
getDouble(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the double representation of the value for the given key.
getDouble(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the double representation of the value for the given key.
getDouble(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getDouble(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
getDoubleType() - Method in class alluxio.grpc.table.Value.Builder
double double_type = 2;
getDoubleType() - Method in class alluxio.grpc.table.Value
double double_type = 2;
getDoubleType() - Method in interface alluxio.grpc.table.ValueOrBuilder
double double_type = 2;
getDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
optional double doubleValue = 1;
getDoubleValue() - Method in class alluxio.grpc.MetricValue
optional double doubleValue = 1;
getDoubleValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
optional double doubleValue = 1;
getDownloadSnapshotMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
 
getDst() - Method in class alluxio.grpc.Route.Builder
required string dst = 2;
getDst() - Method in class alluxio.grpc.Route
required string dst = 2;
getDst() - Method in interface alluxio.grpc.RouteOrBuilder
required string dst = 2;
getDst() - Method in class alluxio.job.CopyJobRequest
 
getDst() - Method in class alluxio.job.MoveJobRequest
 
getDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string dst = 2;
getDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string dst = 2;
getDst() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string dst = 2;
getDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string dst = 2;
getDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string dst = 2;
getDst() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string dst = 2;
getDstBytes() - Method in class alluxio.grpc.Route.Builder
required string dst = 2;
getDstBytes() - Method in class alluxio.grpc.Route
required string dst = 2;
getDstBytes() - Method in interface alluxio.grpc.RouteOrBuilder
required string dst = 2;
getDstBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string dst = 2;
getDstBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string dst = 2;
getDstBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string dst = 2;
getDstBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string dst = 2;
getDstBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string dst = 2;
getDstBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string dst = 2;
getDstPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string dstPath = 3;
getDstPath() - Method in class alluxio.grpc.AddPolicyPOptions
optional string dstPath = 3;
getDstPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string dstPath = 3;
getDstPath() - Method in class alluxio.grpc.RenamePRequest.Builder
the destination path
getDstPath() - Method in class alluxio.grpc.RenamePRequest
the destination path
getDstPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
the destination path
getDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
Deprecated, use new_parent_id/new_name instead
getDstPath() - Method in class alluxio.proto.journal.File.RenameEntry
Deprecated, use new_parent_id/new_name instead
getDstPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
Deprecated, use new_parent_id/new_name instead
getDstPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string dstPath = 3;
getDstPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions
optional string dstPath = 3;
getDstPathBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string dstPath = 3;
getDstPathBytes() - Method in class alluxio.grpc.RenamePRequest.Builder
the destination path
getDstPathBytes() - Method in class alluxio.grpc.RenamePRequest
the destination path
getDstPathBytes() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
the destination path
getDstPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
Deprecated, use new_parent_id/new_name instead
getDstPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry
Deprecated, use new_parent_id/new_name instead
getDstPathBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
Deprecated, use new_parent_id/new_name instead
getDuration(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the time of the key as a duration.
getDuration(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the time of the key as a duration.
getDuration(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getDuration() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 duration = 6;
getDuration() - Method in class alluxio.grpc.CmdSummary
optional int64 duration = 6;
getDuration() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional int64 duration = 6;
getDuration(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getDurationInSec() - Method in class alluxio.master.job.CopyJob
Get duration in seconds.
getDurationInSec() - Method in class alluxio.master.job.DoraLoadJob
Get duration in seconds.
getDurationInSec() - Method in class alluxio.master.job.LoadJob
Get duration in seconds.
getDurationInSec() - Method in class alluxio.master.job.MoveJob
Get duration in seconds.
getDurationMs() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
getDurationMs() - Method in class alluxio.stress.worker.WorkerBenchSummary
 
getEC2ProductCode() - Static method in class alluxio.util.EnvironmentUtils
Gets the EC2 product code if any.
getEmbeddedJournalAddresses(AlluxioConfiguration, NetworkAddressUtils.ServiceType) - Static method in class alluxio.util.ConfigurationUtils
Gets the embedded journal addresses to use for the given service type (either master-raft or job-master-raft).
getEmbeddedJournalPort() - Method in class alluxio.multi.process.MasterNetAddress
 
getEncodedLength() - Method in interface alluxio.network.protocol.EncodedMessage
Returns the number bytes for the message when it is encoded.
getEncodedLength() - Method in enum alluxio.network.protocol.RPCMessage.Type
 
getEncodedLength() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getEncodingType() - Method in class alluxio.s3.ListBucketOptions
 
getEncodingType() - Method in class alluxio.s3.ListBucketResult
 
getEnd() - Method in class alluxio.wire.BlockReadRequest
 
getEnd() - Method in class alluxio.worker.netty.ReadRequest
 
getEndMs() - Method in class alluxio.master.predicate.interval.Interval
 
getEndMs() - Method in class alluxio.stress.client.ClientIOTaskResult
 
getEndMs() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
getEndMs() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getEndTime() - Method in class alluxio.master.job.AbstractJob
Get end time.
getEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 end_time = 9;
getEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional int64 end_time = 9;
getEndTime() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional int64 end_time = 9;
getEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 end_time = 8;
getEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional int64 end_time = 8;
getEndTime() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional int64 end_time = 8;
getEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 end_time = 9;
getEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional int64 end_time = 9;
getEndTime() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional int64 end_time = 9;
getEndTime() - Method in interface alluxio.scheduler.job.Job
 
getEndTimeMs() - Method in class alluxio.stress.worker.WorkerBenchSummary
 
getEntityTag(URIStatus) - Static method in class alluxio.proxy.s3.S3RestUtils
This helper method is used to get the ETag xAttr on an object.
getEntityTag(FileInfo) - Static method in class alluxio.s3.NettyRestUtils
This helper method is used to get the ETag xAttr on an object.
getEntries(int) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntries(int) - Method in class alluxio.grpc.PAcl
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntries(int) - Method in interface alluxio.grpc.PAclOrBuilder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntries(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
getEntries(int) - Method in class alluxio.grpc.SetAclPRequest
the list of ACL entries
getEntries(int) - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the list of ACL entries
getEntries(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntries(int) - Method in class alluxio.proto.journal.File.SetAclEntry
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntries(int) - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntries() - Method in class alluxio.security.authorization.AccessControlList
Returns a list of AclEntry which represent this ACL instance.
getEntries() - Method in class alluxio.security.authorization.DefaultAccessControlList
Returns a list of AclEntry which represent this ACL instance.
getEntries() - Method in class alluxio.security.authorization.ExtendedACLEntries
Returns a list of AclEntry which represent this ACL instance.
getEntriesBuilder(int) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesBuilder(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
getEntriesBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesBuilderList() - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesBuilderList() - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
getEntriesBuilderList() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesCount() - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesCount() - Method in class alluxio.grpc.PAcl
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesCount() - Method in interface alluxio.grpc.PAclOrBuilder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesCount() - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
getEntriesCount() - Method in class alluxio.grpc.SetAclPRequest
the list of ACL entries
getEntriesCount() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the list of ACL entries
getEntriesCount() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesCount() - Method in class alluxio.proto.journal.File.SetAclEntry
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesCount() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesList() - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesList() - Method in class alluxio.grpc.PAcl
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesList() - Method in interface alluxio.grpc.PAclOrBuilder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesList() - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
getEntriesList() - Method in class alluxio.grpc.SetAclPRequest
the list of ACL entries
getEntriesList() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the list of ACL entries
getEntriesList() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesList() - Method in class alluxio.proto.journal.File.SetAclEntry
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesList() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesOrBuilder(int) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesOrBuilder(int) - Method in class alluxio.grpc.PAcl
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesOrBuilder(int) - Method in interface alluxio.grpc.PAclOrBuilder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesOrBuilder(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
getEntriesOrBuilder(int) - Method in class alluxio.grpc.SetAclPRequest
the list of ACL entries
getEntriesOrBuilder(int) - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the list of ACL entries
getEntriesOrBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesOrBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesOrBuilder(int) - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesOrBuilderList() - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesOrBuilderList() - Method in class alluxio.grpc.PAcl
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesOrBuilderList() - Method in interface alluxio.grpc.PAclOrBuilder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
getEntriesOrBuilderList() - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
getEntriesOrBuilderList() - Method in class alluxio.grpc.SetAclPRequest
the list of ACL entries
getEntriesOrBuilderList() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the list of ACL entries
getEntriesOrBuilderList() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesOrBuilderList() - Method in class alluxio.proto.journal.File.SetAclEntry
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntriesOrBuilderList() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
repeated .alluxio.proto.shared.AclEntry entries = 4;
getEntry() - Method in interface alluxio.master.journal.JournalReader
Returns the next entry in the journal.
getEntry() - Method in class alluxio.master.journal.SingleEntryJournaled
 
getEntry() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
getEntryCount() - Method in class alluxio.grpc.BackupPStatus.Builder
optional int64 entryCount = 5;
getEntryCount() - Method in class alluxio.grpc.BackupPStatus
optional int64 entryCount = 5;
getEntryCount() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional int64 entryCount = 5;
getEntryCount() - Method in class alluxio.wire.BackupStatus
 
getEntryCounter() - Method in class alluxio.master.backup.BackupTracker
 
getEntryMap() - Method in class alluxio.collections.LockPool
 
getEnum(PropertyKey, Class<T>) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as an enum value.
getEnum(PropertyKey, Class<T>) - Static method in class alluxio.conf.Configuration
Gets the value for the given key as an enum value.
getEnum(PropertyKey, Class<T>) - Method in class alluxio.conf.InstancedConfiguration
 
getEnum(PropertyKey, Class<T>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getEnumType() - Method in class alluxio.conf.PropertyKey
 
getEof() - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
getEof() - Method in class alluxio.grpc.SnapshotData
Deprecated. 
getEof() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
Deprecated. 
getEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
getEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool eof = 5;
getEof() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool eof = 5;
getEquatable() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatable() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatable() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableBuilder() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableOrBuilder() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.EquatableValueSet equatable = 2;
getEquatableOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
getError() - Method in class alluxio.thread.AutopsyThread
Gets the crashing error.
getError() - Method in class alluxio.wire.BackupStatus
 
getError() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getError() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getError() - Method in class alluxio.worker.netty.ReadRequestContext
 
getError() - Method in class alluxio.worker.netty.WriteRequestContext
 
getErrorCode(Throwable) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the corresponding error code of a throwable.
getErrorCode() - Method in exception alluxio.s3.S3Exception
 
getErrored() - Method in class alluxio.s3.DeleteObjectsResult
 
getErrorMessage() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorMessage = 7;
getErrorMessage() - Method in class alluxio.grpc.ActionInfo
optional string errorMessage = 7;
getErrorMessage() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string errorMessage = 7;
getErrorMessage() - Method in class alluxio.grpc.CmdSummary.Builder
optional string errorMessage = 7;
getErrorMessage() - Method in class alluxio.grpc.CmdSummary
optional string errorMessage = 7;
getErrorMessage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional string errorMessage = 7;
getErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorMessage = 2;
getErrorMessage() - Method in class alluxio.grpc.JobInfo
optional string errorMessage = 2;
getErrorMessage() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string errorMessage = 2;
getErrorMessage() - Method in class alluxio.job.plan.meta.PlanInfo
 
getErrorMessage() - Method in interface alluxio.job.wire.JobInfo
 
getErrorMessage() - Method in class alluxio.job.wire.PlanInfo
 
getErrorMessage() - Method in class alluxio.job.wire.TaskInfo
 
getErrorMessage() - Method in class alluxio.job.wire.WorkflowInfo
 
getErrorMessage() - Method in class alluxio.job.workflow.WorkflowExecution
 
getErrorMessageBytes() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorMessage = 7;
getErrorMessageBytes() - Method in class alluxio.grpc.ActionInfo
optional string errorMessage = 7;
getErrorMessageBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string errorMessage = 7;
getErrorMessageBytes() - Method in class alluxio.grpc.CmdSummary.Builder
optional string errorMessage = 7;
getErrorMessageBytes() - Method in class alluxio.grpc.CmdSummary
optional string errorMessage = 7;
getErrorMessageBytes() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional string errorMessage = 7;
getErrorMessageBytes() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorMessage = 2;
getErrorMessageBytes() - Method in class alluxio.grpc.JobInfo
optional string errorMessage = 2;
getErrorMessageBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string errorMessage = 2;
getErrorMsg() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorMsg = 5;
getErrorMsg() - Method in class alluxio.grpc.JobProgress
optional string errorMsg = 5;
getErrorMsg() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional string errorMsg = 5;
getErrorMsgBytes() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorMsg = 5;
getErrorMsgBytes() - Method in class alluxio.grpc.JobProgress
optional string errorMsg = 5;
getErrorMsgBytes() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional string errorMsg = 5;
getErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
Deprecated.
getErrors() - Method in class alluxio.grpc.ConfigCheckReport
Deprecated.
getErrors() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Deprecated.
getErrors() - Method in class alluxio.grpc.PolicyStatus.Builder
Deprecated.
getErrors() - Method in class alluxio.grpc.PolicyStatus
Deprecated.
getErrors() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
Deprecated.
getErrors() - Method in class alluxio.stress.client.ClientIOTaskResult
 
getErrors() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
getErrors() - Method in class alluxio.stress.graph.Graph
 
getErrors() - Method in interface alluxio.stress.TaskResult
 
getErrors() - Method in class alluxio.stress.worker.IOTaskResult
 
getErrors() - Method in class alluxio.stress.worker.IOTaskSummary
 
getErrors() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getErrorsCount() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
getErrorsCount() - Method in class alluxio.grpc.ConfigCheckReport
 
getErrorsCount() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getErrorsCount() - Method in class alluxio.grpc.PolicyStatus.Builder
 
getErrorsCount() - Method in class alluxio.grpc.PolicyStatus
 
getErrorsCount() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
map<string, string> errors = 10;
getErrorsMap() - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
getErrorsMap() - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
getErrorsMap() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getErrorsMap() - Method in class alluxio.grpc.PolicyStatus.Builder
map<string, string> errors = 10;
getErrorsMap() - Method in class alluxio.grpc.PolicyStatus
map<string, string> errors = 10;
getErrorsMap() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
map<string, string> errors = 10;
getErrorsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
getErrorsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
getErrorsOrDefault(String, InconsistentProperties) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getErrorsOrDefault(String, String) - Method in class alluxio.grpc.PolicyStatus.Builder
map<string, string> errors = 10;
getErrorsOrDefault(String, String) - Method in class alluxio.grpc.PolicyStatus
map<string, string> errors = 10;
getErrorsOrDefault(String, String) - Method in interface alluxio.grpc.PolicyStatusOrBuilder
map<string, string> errors = 10;
getErrorsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
getErrorsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
getErrorsOrThrow(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getErrorsOrThrow(String) - Method in class alluxio.grpc.PolicyStatus.Builder
map<string, string> errors = 10;
getErrorsOrThrow(String) - Method in class alluxio.grpc.PolicyStatus
map<string, string> errors = 10;
getErrorsOrThrow(String) - Method in interface alluxio.grpc.PolicyStatusOrBuilder
map<string, string> errors = 10;
getErrorString(String, String, String) - Method in class alluxio.fuse.options.BaseValueConverter
Format an error string describing the reason why the conversion failed.
getErrorType() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorType = 6;
getErrorType() - Method in class alluxio.grpc.ActionInfo
optional string errorType = 6;
getErrorType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string errorType = 6;
getErrorType() - Method in class alluxio.grpc.ErrorInfo.Builder
optional .alluxio.grpc.ErrorType errorType = 1;
getErrorType() - Method in class alluxio.grpc.ErrorInfo
optional .alluxio.grpc.ErrorType errorType = 1;
getErrorType() - Method in interface alluxio.grpc.ErrorInfoOrBuilder
optional .alluxio.grpc.ErrorType errorType = 1;
getErrorType() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorType = 15;
getErrorType() - Method in class alluxio.grpc.JobInfo
optional string errorType = 15;
getErrorType() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string errorType = 15;
getErrorType() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorType = 6;
getErrorType() - Method in class alluxio.grpc.JobProgress
optional string errorType = 6;
getErrorType() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional string errorType = 6;
getErrorType(Throwable) - Static method in class alluxio.job.ErrorUtils
 
getErrorType() - Method in class alluxio.job.plan.meta.PlanInfo
 
getErrorType() - Method in interface alluxio.job.wire.JobInfo
 
getErrorType() - Method in class alluxio.job.wire.PlanInfo
 
getErrorType() - Method in class alluxio.job.wire.TaskInfo
 
getErrorType() - Method in class alluxio.job.wire.WorkflowInfo
 
getErrorType() - Method in class alluxio.job.workflow.WorkflowExecution
 
getErrorTypeBytes() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorType = 6;
getErrorTypeBytes() - Method in class alluxio.grpc.ActionInfo
optional string errorType = 6;
getErrorTypeBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string errorType = 6;
getErrorTypeBytes() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorType = 15;
getErrorTypeBytes() - Method in class alluxio.grpc.JobInfo
optional string errorType = 15;
getErrorTypeBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string errorType = 15;
getErrorTypeBytes() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorType = 6;
getErrorTypeBytes() - Method in class alluxio.grpc.JobProgress
optional string errorType = 6;
getErrorTypeBytes() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional string errorType = 6;
getETag() - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
 
getETag() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getEtag() - Method in class alluxio.proxy.s3.CopyPartResult
 
getETag() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getEtag() - Method in class alluxio.s3.CopyObjectResult
 
getEtcdClient() - Method in class alluxio.membership.AlluxioEtcdClient
Get the jetcd client instance.
getEvictBatchSize() - Method in class alluxio.master.metastore.caching.CacheConfiguration
 
getEvictor() - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
getEvictorClass() - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
 
getException() - Method in class alluxio.client.file.ConfigHashSync
 
getException() - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Gets the exception during execution.
getException() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the exception thrown by the base computation, or a CancellationException if cancelled, or null if none or if the method has not yet completed.
getExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions.Builder
Mount info will be excluded from the list status response if this field is set to true.
getExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions
Mount info will be excluded from the list status response if this field is set to true.
getExcludeMountInfo() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
Mount info will be excluded from the list status response if this field is set to true.
getExecution(WorkflowConfig) - Method in enum alluxio.job.workflow.WorkflowExecutionRegistry
Gets the WorkflowExecution from workflow config.
getExecutor() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getExecutorService() - Method in class alluxio.master.AbstractMaster
 
getExecutorService() - Method in class alluxio.worker.AbstractWorker
 
getExistingDirectoryStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getExistingDirectoryStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
getExistingDirectoryStatus(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getExistingDirectoryStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getExistingDirectoryStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the directory status.
getExistingDirectoryStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getExistingFileStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getExistingFileStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
getExistingFileStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getExistingFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file status.
getExistingFileStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getExistingInodeCount() - Method in class alluxio.master.file.meta.LockedInodePath
 
getExistingStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getExistingStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
getExistingStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getExistingStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file or directory status.
getExistingStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getExists() - Method in class alluxio.grpc.ExistsPResponse.Builder
optional bool exists = 1;
getExists() - Method in class alluxio.grpc.ExistsPResponse
optional bool exists = 1;
getExists() - Method in interface alluxio.grpc.ExistsPResponseOrBuilder
optional bool exists = 1;
getExists() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional bool exists = 3;
getExists() - Method in class alluxio.grpc.SnapshotMetadata
optional bool exists = 3;
getExists() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
optional bool exists = 3;
getExistsMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getExistsMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getExitCode() - Method in class alluxio.shell.CommandReturn
Gets the exit code.
getExitCode() - Method in exception alluxio.util.ShellUtils.ExitCodeException
Gets the exit code.
getExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 expiryMs = 3;
getExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional int64 expiryMs = 3;
getExpiryMs() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional int64 expiryMs = 3;
getExtendedEntries() - Method in class alluxio.security.authorization.AccessControlList
 
getFactory() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the factory used for constructing new workers.
getFailedCmdCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Gets the number of failed commands.
getFailedCount() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Gets the number of failed jobs.
getFailedFiles() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Gets failed files.
getFailedFiles() - Method in class alluxio.cli.fs.command.job.JobAttempt
Get failed files if there's any.
getFailedFiles() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Return a copy of failed paths.
getFailedMembers() - Method in class alluxio.membership.EtcdMembershipManager
 
getFailedMembers() - Method in class alluxio.membership.MasterMembershipManager
 
getFailedMembers() - Method in interface alluxio.membership.MembershipManager
Get all failed workers.
getFailedMembers() - Method in class alluxio.membership.StaticMembershipManager
 
getFailedNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
Get failed node infos node info [ ].
getFailedPaths(long) - Method in class alluxio.master.job.JobMaster
 
getFailures(int) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailures(int) - Method in class alluxio.grpc.CopyResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailures(int) - Method in interface alluxio.grpc.CopyResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailures(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailures(int) - Method in class alluxio.grpc.LoadFileResponse
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailures(int) - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailures(int) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailures(int) - Method in class alluxio.grpc.MoveResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailures(int) - Method in interface alluxio.grpc.MoveResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresBuilder(int) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresBuilder(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresBuilder(int) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresBuilderList() - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresBuilderList() - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresBuilderList() - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresCount() - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresCount() - Method in class alluxio.grpc.CopyResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresCount() - Method in interface alluxio.grpc.CopyResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresCount() - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresCount() - Method in class alluxio.grpc.LoadFileResponse
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresCount() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresCount() - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresCount() - Method in class alluxio.grpc.MoveResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresCount() - Method in interface alluxio.grpc.MoveResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresList() - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresList() - Method in class alluxio.grpc.CopyResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresList() - Method in interface alluxio.grpc.CopyResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresList() - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresList() - Method in class alluxio.grpc.LoadFileResponse
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresList() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresList() - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresList() - Method in class alluxio.grpc.MoveResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresList() - Method in interface alluxio.grpc.MoveResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilder(int) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilder(int) - Method in class alluxio.grpc.CopyResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilder(int) - Method in interface alluxio.grpc.CopyResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilder(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresOrBuilder(int) - Method in class alluxio.grpc.LoadFileResponse
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresOrBuilder(int) - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresOrBuilder(int) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilder(int) - Method in class alluxio.grpc.MoveResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilder(int) - Method in interface alluxio.grpc.MoveResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilderList() - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilderList() - Method in class alluxio.grpc.CopyResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilderList() - Method in interface alluxio.grpc.CopyResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilderList() - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresOrBuilderList() - Method in class alluxio.grpc.LoadFileResponse
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresOrBuilderList() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
getFailuresOrBuilderList() - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilderList() - Method in class alluxio.grpc.MoveResponse
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFailuresOrBuilderList() - Method in interface alluxio.grpc.MoveResponseOrBuilder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
getFalsePositiveRatio() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getFalsePositiveRatio() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getFalsePositiveRatio() - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getFatalError() - Method in class alluxio.wire.MasterWebUIBrowse
Gets fatal error.
getFatalError() - Method in class alluxio.wire.MasterWebUIData
Gets fatal error.
getFatalError() - Method in class alluxio.wire.MasterWebUILogs
Gets fatal error.
getFatalError() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets fatal error.
getFatalError() - Method in class alluxio.wire.WorkerWebUILogs
Gets fatal error.
getFieldRange() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
getFieldRanges(int) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRanges(int) - Method in class alluxio.grpc.GetWorkerReportPOptions
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRanges(int) - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRangesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRangesCount() - Method in class alluxio.grpc.GetWorkerReportPOptions
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRangesCount() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRangesList() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRangesList() - Method in class alluxio.grpc.GetWorkerReportPOptions
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldRangesList() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
getFieldValue(T) - Method in class alluxio.collections.IndexDefinition
Gets the value of the field that serves as index.
getFile() - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
getFile() - Method in class alluxio.grpc.FileFailure
required .alluxio.grpc.block.File file = 1;
getFile() - Method in interface alluxio.grpc.FileFailureOrBuilder
required .alluxio.grpc.block.File file = 1;
getFileBlockInfo(long) - Method in class alluxio.wire.FileInfo
 
getFileBlockInfoList(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileBlockInfoList(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Gets the FileBlockInfo for all blocks of a file.
getFileBlockInfoList(AlluxioURI) - Method in class alluxio.master.file.meta.FileSystemMasterView
 
getFileBlockInfos() - Method in class alluxio.client.file.URIStatus
 
getFileBlockInfos(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfos(int) - Method in class alluxio.grpc.FileInfo
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfos(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfos() - Method in class alluxio.wire.FileInfo
 
getFileBlockInfosBuilder(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosBuilderList() - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosCount() - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosCount() - Method in class alluxio.grpc.FileInfo
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosList() - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosList() - Method in class alluxio.grpc.FileInfo
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosList() - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosOrBuilder(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosOrBuilder(int) - Method in class alluxio.grpc.FileInfo
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosOrBuilder(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosOrBuilderList() - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosOrBuilderList() - Method in class alluxio.grpc.FileInfo
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockInfosOrBuilderList() - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
getFileBlockLocations(FileStatus, long, long) - Method in class alluxio.hadoop.AbstractFileSystem
 
getFileBlocks() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file blocks.
getFileBlocksOnTier() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets file blocks on tier.
getFileBucket(int, String) - Static method in interface alluxio.client.file.cache.store.PageStoreDir
 
getFileBuckets() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getFileBuilder() - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
getFileCount() - Method in class alluxio.client.file.ListStatusPartialResult
 
getFileCount() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileCount = 2;
getFileCount() - Method in class alluxio.grpc.JobProgress
optional int64 fileCount = 2;
getFileCount() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 fileCount = 2;
getFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
The total number of files in the listing directory, (i.e.
getFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse
The total number of files in the listing directory, (i.e.
getFileCount() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
The total number of files in the listing directory, (i.e.
getFileCount() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Get file count.
getFileData() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file data.
getFileData() - Method in class alluxio.wire.MasterWebUILogs
Gets file data.
getFileData() - Method in class alluxio.wire.WorkerWebUILogs
Gets file data.
getFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string file_date_pattern = 6;
getFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions
optional string file_date_pattern = 6;
getFileDatePattern() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string file_date_pattern = 6;
getFileDatePatternBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string file_date_pattern = 6;
getFileDatePatternBytes() - Method in class alluxio.grpc.AddPolicyPOptions
optional string file_date_pattern = 6;
getFileDatePatternBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string file_date_pattern = 6;
getFileDoesNotExistException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file does not exist exception.
getFileId() - Method in class alluxio.client.file.cache.PageId
 
getFileId() - Method in class alluxio.client.file.URIStatus
 
getFileId() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 fileId = 1;
getFileId() - Method in class alluxio.grpc.FileInfo
optional int64 fileId = 1;
getFileId() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 fileId = 1;
getFileId() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
the id of the file
getFileId() - Method in class alluxio.grpc.GetFileInfoPRequest
the id of the file
getFileId() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
the id of the file
getFileId() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
optional int64 fileId = 1;
getFileId() - Method in class alluxio.grpc.GetFilePathPRequest
optional int64 fileId = 1;
getFileId() - Method in interface alluxio.grpc.GetFilePathPRequestOrBuilder
optional int64 fileId = 1;
getFileId() - Method in class alluxio.grpc.PersistFile.Builder
optional int64 fileId = 1;
getFileId() - Method in class alluxio.grpc.PersistFile
optional int64 fileId = 1;
getFileId() - Method in interface alluxio.grpc.PersistFileOrBuilder
optional int64 fileId = 1;
getFileId(long) - Static method in class alluxio.master.block.BlockId
 
getFileId(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileId(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Returns the file id for a given path.
getFileId(AlluxioURI) - Method in class alluxio.master.file.meta.FileSystemMasterView
Returns the file id for a given path.
getFileId() - Method in class alluxio.master.file.PersistJob
 
getFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
getFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
optional int64 file_id = 1;
getFileId() - Method in interface alluxio.proto.journal.File.AsyncPersistRequestEntryOrBuilder
optional int64 file_id = 1;
getFileId() - Method in class alluxio.wire.FileInfo
 
getFileId() - Method in class alluxio.wire.PersistFile
 
getFileInfo() - Method in class alluxio.client.file.URIStatus
This is an experimental API.
getFileInfo() - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in class alluxio.grpc.CreateFilePResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterJobServiceGrpc.AsyncService
Returns the file information for a file or directory identified by the given file id.
getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceBlockingStub
Returns the file information for a file or directory identified by the given file id.
getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceFutureStub
Returns the file information for a file or directory identified by the given file id.
getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceStub
Returns the file information for a file or directory identified by the given file id.
getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
Returns the file information for a file or directory identified by the given file id.
getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
Returns the file information for a file or directory identified by the given file id.
getFileInfo(GetFileInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
Returns the file information for a file or directory identified by the given file id.
getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
Returns the file information for a file or directory identified by the given file id.
getFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in interface alluxio.grpc.GetFileInfoPResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in class alluxio.grpc.GetStatusPResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in interface alluxio.grpc.GetStatusPResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileInfo(AlluxioURI, GetStatusContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileInfo(long) - Method in interface alluxio.master.file.FileSystemMaster
Returns the FileInfo for a given file id.
getFileInfo(AlluxioURI, GetStatusContext) - Method in interface alluxio.master.file.FileSystemMaster
Returns the FileInfo for a given path.
getFileInfo(long) - Method in class alluxio.master.file.FileSystemMasterClient
 
getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterJobServiceHandler
 
getFileInfo(GetFileInfoPRequest, StreamObserver<GetFileInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getFileInfo(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
Returns the FileInfo for a given path.
getFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfo(long) - Method in interface alluxio.worker.block.BlockWorker
Gets the file information.
getFileInfo(String, GetStatusPOptions) - Method in interface alluxio.worker.dora.DoraWorker
Gets the file information.
getFileInfo(String, GetStatusPOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
getFileInfo(long) - Method in class alluxio.worker.file.FileSystemMasterClient
 
getFileInfoBuilder() - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoBuilder() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoBuilder() - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoBuilder() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.grpc.CreateFilePResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.grpc.GetFileInfoPResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in interface alluxio.grpc.GetFileInfoPResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.grpc.GetStatusPResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in interface alluxio.grpc.GetStatusPResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
getFileInfoOrBuilder() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
GetFileInfoPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFileInfoPOptions
GetFileInfoPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFileInfoPOptions
GetFileInfoPOptionsOrBuilder - Interface in alluxio.grpc
 
GetFileInfoPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFileInfoPRequest
GetFileInfoPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFileInfoPRequest
GetFileInfoPRequestOrBuilder - Interface in alluxio.grpc
 
GetFileInfoPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFileInfoPResponse
GetFileInfoPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFileInfoPResponse
GetFileInfoPResponseOrBuilder - Interface in alluxio.grpc
 
getFileInfos(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfos(int) - Method in class alluxio.grpc.ListStatusPartialPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfos(int) - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfos(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfos(int) - Method in class alluxio.grpc.ListStatusPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfos(int) - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfos() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file infos.
getFileInfos() - Method in class alluxio.wire.MasterWebUIData
Gets file infos.
getFileInfos() - Method in class alluxio.wire.MasterWebUILogs
Gets file infos.
getFileInfos() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets file infos.
getFileInfos() - Method in class alluxio.wire.WorkerWebUILogs
Gets file infos.
getFileInfosBuilder(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosBuilder(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosBuilderList() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosBuilderList() - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosCount() - Method in class alluxio.grpc.ListStatusPartialPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosCount() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosCount() - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosCount() - Method in class alluxio.grpc.ListStatusPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosCount() - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosList() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosList() - Method in class alluxio.grpc.ListStatusPartialPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosList() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosList() - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosList() - Method in class alluxio.grpc.ListStatusPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosList() - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPartialPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilder(int) - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilder(int) - Method in class alluxio.grpc.ListStatusPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilder(int) - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPartialPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilderList() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilderList() - Method in class alluxio.grpc.ListStatusPResponse
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileInfosOrBuilderList() - Method in interface alluxio.grpc.ListStatusPResponseOrBuilder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
getFileLength() - Method in class alluxio.fuse.file.FileStatus
 
getFileLocations(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFileLocations(String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
 
getFileLocations(String) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
 
getFileLocations(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
getFileLocations(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFileLocations(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getFileLocations(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileLocations(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the list of locations of the indicated path.
getFileLocations(String, FileLocationOptions) - Method in interface alluxio.underfs.UnderFileSystem
Gets the list of locations of the indicated path given options.
getFileLocations(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileLocations(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getFileLocations() - Method in class alluxio.util.webui.UIFileInfo
Gets file locations.
getFileName() - Method in class alluxio.cli.fs.command.FileLocation
Get the file name.
getFileOrBuilder() - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
getFileOrBuilder() - Method in class alluxio.grpc.FileFailure
required .alluxio.grpc.block.File file = 1;
getFileOrBuilder() - Method in interface alluxio.grpc.FileFailureOrBuilder
required .alluxio.grpc.block.File file = 1;
getFilePath(String, AlluxioConfiguration) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Removes Constants.HEADER and hostname:port information from a path, leaving only the local file path.
getFilePath(long) - Method in interface alluxio.client.file.FileSystemMasterClient
 
getFilePath(long) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getFilePath() - Method in class alluxio.grpc.ActionInfo.Builder
optional string filePath = 4;
getFilePath() - Method in class alluxio.grpc.ActionInfo
optional string filePath = 4;
getFilePath() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string filePath = 4;
getFilePath(GetFilePathPRequest, StreamObserver<GetFilePathPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Returns the file path of a file id
getFilePath(GetFilePathPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Returns the file path of a file id
getFilePath(GetFilePathPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Returns the file path of a file id
getFilePath(GetFilePathPRequest, StreamObserver<GetFilePathPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Returns the file path of a file id
getFilePath() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string filePath = 3;
getFilePath() - Method in class alluxio.grpc.GetActionInfoRequest
optional string filePath = 3;
getFilePath() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string filePath = 3;
getFilePath() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePath = 3;
getFilePath() - Method in class alluxio.grpc.JobStatusBlock
optional string filePath = 3;
getFilePath() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional string filePath = 3;
getFilePath() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
getFilePath() - Method in class alluxio.job.plan.persist.PersistConfig
 
getFilePath() - Method in class alluxio.job.wire.SimpleJobStatusBlock
Get file path of the job.
getFilePath(GetFilePathPRequest, StreamObserver<GetFilePathPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getFilePath() - Method in class alluxio.master.job.common.CmdInfo
Get file path.
getFilePath() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Set file path.
getFilePathBytes() - Method in class alluxio.grpc.ActionInfo.Builder
optional string filePath = 4;
getFilePathBytes() - Method in class alluxio.grpc.ActionInfo
optional string filePath = 4;
getFilePathBytes() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string filePath = 4;
getFilePathBytes() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string filePath = 3;
getFilePathBytes() - Method in class alluxio.grpc.GetActionInfoRequest
optional string filePath = 3;
getFilePathBytes() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string filePath = 3;
getFilePathBytes() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePath = 3;
getFilePathBytes() - Method in class alluxio.grpc.JobStatusBlock
optional string filePath = 3;
getFilePathBytes() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional string filePath = 3;
getFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePathFailed = 4;
getFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock
optional string filePathFailed = 4;
getFilePathFailed() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional string filePathFailed = 4;
getFilePathFailedBytes() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePathFailed = 4;
getFilePathFailedBytes() - Method in class alluxio.grpc.JobStatusBlock
optional string filePathFailed = 4;
getFilePathFailedBytes() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional string filePathFailed = 4;
GetFilePathPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFilePathPRequest
GetFilePathPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFilePathPRequest
GetFilePathPRequestOrBuilder - Interface in alluxio.grpc
 
GetFilePathPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFilePathPResponse
GetFilePathPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetFilePathPResponse
GetFilePathPResponseOrBuilder - Interface in alluxio.grpc
 
getFileRegion() - Method in class alluxio.worker.http.HttpResponseContext
Get the file region to read from the worker side.
getFiles(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the files (on the local filesystem) that match the given input path.
getFileSize() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileSize = 3;
getFileSize() - Method in class alluxio.grpc.JobProgress
optional int64 fileSize = 3;
getFileSize() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 fileSize = 3;
getFileSize(String, FileSystem, RetryPolicy) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
get file size for a given filePath, return 0 if exceeding retries.
getFileSize() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Get file size.
getFileSizeHistogram() - Method in class alluxio.master.file.meta.InodeTree
 
getFileSizeHistogram() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getFileSizeTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting file size.
getFilesPathFailed() - Method in class alluxio.job.wire.SimpleJobStatusBlock
Get failed file path of the job.
getFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int32 files_skipped = 3;
getFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse
optional int32 files_skipped = 3;
getFilesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
optional int32 files_skipped = 3;
getFileStatus(String, GetStatusOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFileStatus() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
getFileStatus() - Method in class alluxio.fuse.file.FuseFileInStream
 
getFileStatus() - Method in class alluxio.fuse.file.FuseFileOutStream
 
getFileStatus() - Method in interface alluxio.fuse.file.FuseFileStream
 
getFileStatus() - Method in class alluxio.fuse.file.FusePositionReader
 
getFileStatus() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
getFileStatus(Path) - Method in class alluxio.hadoop.AbstractFileSystem
If the file does not exist in Alluxio, query it from HDFS.
getFileStatus(Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
Gets stat information on a file.
getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file status.
getFileStatus(String, GetStatusOptions) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file status.
getFileStatus(String, GetStatusOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting file status.
getFilesToLoad() - Method in class alluxio.master.job.DoraLoadJob.DoraLoadTask
Get files to load of this task.
getFilesToPersist() - Method in class alluxio.wire.PersistCommandOptions
 
getFileStream() - Method in class alluxio.fuse.file.FuseFileEntry
Gets the fuse file stream for this entry.
getFileSystem() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
Get the file system on which FuseFileSystem is based.
getFileSystem() - Method in class alluxio.job.JobServerContext
 
getFileSystemClient() - Method in class alluxio.multi.process.Clients
 
getFileSystemClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getFilesystemContext() - Method in class alluxio.multi.process.MultiProcessCluster
 
getFileSystemForUser(String) - Method in class alluxio.worker.s3.S3NettyHandler
 
getFileSystemHeartbeatMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
getFileSystemMasterClient() - Method in class alluxio.multi.process.Clients
 
getFileSystemMasterView() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getFileSystemMasterView() - Method in interface alluxio.master.file.FileSystemMaster
 
getFileSystemName() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
getFileSystemName() - Method in class alluxio.fuse.StackFS
 
getFileSystemName() - Method in interface alluxio.jnifuse.FuseFileSystem
 
getFileSystemOptions() - Method in class alluxio.fuse.options.FuseOptions.Builder
 
getFileSystemOptions() - Method in class alluxio.fuse.options.FuseOptions
 
getFileTransferType() - Method in class alluxio.worker.s3.S3NettyHandler
Get the FileTransferType of the netty server.
getFilter() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string filter = 5;
getFilter() - Method in class alluxio.grpc.AddPolicyPOptions
optional string filter = 5;
getFilter() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string filter = 5;
getFilter(int) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilter(int) - Method in class alluxio.grpc.GetMasterInfoPOptions
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilter(int) - Method in interface alluxio.grpc.GetMasterInfoPOptionsOrBuilder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilter() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilter() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterBuilder() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterBuilder() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string filter = 5;
getFilterBytes() - Method in class alluxio.grpc.AddPolicyPOptions
optional string filter = 5;
getFilterBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string filter = 5;
getFilterCount() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilterCount() - Method in class alluxio.grpc.GetMasterInfoPOptions
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilterCount() - Method in interface alluxio.grpc.GetMasterInfoPOptionsOrBuilder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilterList() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilterList() - Method in class alluxio.grpc.GetMasterInfoPOptions
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilterList() - Method in interface alluxio.grpc.GetMasterInfoPOptionsOrBuilder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
getFilterMetricName() - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
getFilterMetricName() - Method in interface alluxio.metrics.MultiValueMetricsAggregator
 
getFilterName() - Method in class alluxio.master.predicate.DatePredicate.Factory
 
getFilterName() - Method in class alluxio.master.predicate.DatePredicate.LastModifiedDateFactory
 
getFilterName() - Method in class alluxio.master.predicate.TimePredicate.DateFromFileNameOlderThanFactory
 
getFilterName() - Method in class alluxio.master.predicate.TimePredicate.Factory
 
getFilterName() - Method in class alluxio.master.predicate.TimePredicate.UnmodifiedForFactory
 
getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterOrBuilder() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterOrBuilder() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilterOrBuilder() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional .alluxio.proto.journal.FileFilter filter = 12;
getFilters(int) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFilters(int) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFilters(int) - Method in interface alluxio.grpc.GetBlockMasterInfoPOptionsOrBuilder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFilters() - Method in interface alluxio.metrics.MetricsAggregator
 
getFiltersCount() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFiltersCount() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFiltersCount() - Method in interface alluxio.grpc.GetBlockMasterInfoPOptionsOrBuilder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFiltersList() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFiltersList() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFiltersList() - Method in interface alluxio.grpc.GetBlockMasterInfoPOptionsOrBuilder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
getFingerprint(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFingerprint(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getFingerprint(String) - Method in interface alluxio.underfs.UnderFileSystem
Deprecated. 
getFingerprint(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFirst(V) - Method in interface alluxio.collections.FieldIndex
Gets an object from the set of objects with the specified field value.
getFirst(V) - Method in class alluxio.collections.NonUniqueFieldIndex
 
getFirst() - Method in class alluxio.collections.Pair
 
getFirst(V) - Method in class alluxio.collections.UniqueFieldIndex
 
getFirstByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Gets the object from the set of objects with the specified field value.
getFirstLevelDirectory(String) - Static method in class alluxio.util.io.PathUtils
Gets the first level directory of the path.
getFlush() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool flush = 5;
getFlush() - Method in class alluxio.grpc.WriteRequestCommand
optional bool flush = 5;
getFlush() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional bool flush = 5;
getFolder() - Method in class alluxio.grpc.FileInfo.Builder
optional bool folder = 9;
getFolder() - Method in class alluxio.grpc.FileInfo
optional bool folder = 9;
getFolder() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool folder = 9;
getFolderSuffix() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get suffix used to encode a directory.
getFolderSuffix() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getFolderSuffix() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getForced() - Method in class alluxio.grpc.FreePOptions.Builder
optional bool forced = 2;
getForced() - Method in class alluxio.grpc.FreePOptions
optional bool forced = 2;
getForced() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
optional bool forced = 2;
getForkJoinTaskTag() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the tag for this task.
getFormat() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
getFormat() - Method in class alluxio.grpc.GetJobProgressPResponse
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
getFormat() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
getFormat() - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
getFormat() - Method in class alluxio.grpc.JobProgressPOptions
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
getFormat() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
getFormattedOutput() - Method in class alluxio.shell.CommandReturn
Formats the object to more readable format.
getForPath(String) - Method in class alluxio.membership.AlluxioEtcdClient
Get latest value attached to the path.
getFqdnHost(InetSocketAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets FQDN(Full Qualified Domain Name) from Java representations of network address, except String representation which should be handled by NetworkAddressUtils.resolveHostName(String) which will handle the situation where hostname is null.
getFqdnHost(WorkerNetAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets FQDN(Full Qualified Domain Name) from Alluxio representation of network address.
getFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 freeBytes = 3;
getFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo
optional int64 freeBytes = 3;
getFreeBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int64 freeBytes = 3;
getFreeBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getFreeBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getFreeBytesOnTiers() - Method in class alluxio.worker.block.BlockWorkerMetrics
 
getFreeCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets free capacity.
getFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets free capacity.
getFreeCapacityBytes() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get free capacity in bytes.
getFreeMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getFreeSpacePercent() - Method in class alluxio.util.webui.NodeInfo
Gets free space percent.
getFreeSpacePercent() - Method in class alluxio.util.webui.StorageTierInfo
Gets free space percent.
getFreeWorkerMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getFromMetaStore(String) - Method in class alluxio.worker.dora.DoraMetaManager
Gets file meta from the metastore.
getFromUfs(String) - Method in class alluxio.worker.dora.DoraMetaManager
Gets file meta from UFS.
getFs() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getFsClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getFsClient() - Method in class alluxio.worker.s3.S3NettyHandler
Get system user FileSystem object.
getFsContext() - Method in class alluxio.job.JobServerContext
 
getFsPath(String, URIStatus) - Method in class alluxio.hadoop.AbstractFileSystem
Used to get FS native path from Alluxio file status.
getFsPath(String, URIStatus) - Method in class alluxio.hadoop.FileSystem
 
getFsScheme(URI) - Method in class alluxio.hadoop.AbstractFileSystem
Used to get FS scheme.
getFsScheme(URI) - Method in class alluxio.hadoop.FileSystem
 
getFsType() - Method in class alluxio.util.UnixMountInfo
 
getFullMetricName() - Method in class alluxio.metrics.Metric
 
getFullPath(String, String) - Static method in class alluxio.s3.NettyRestUtils
Gets the full path combined by bucket name and object name.
getFuseMethodNames() - Static method in class alluxio.fuse.FuseConstants
 
getFuseMountOptions() - Method in class alluxio.fuse.options.FuseOptions.Builder
 
getFuseMountOptions() - Method in class alluxio.fuse.options.FuseOptions
 
getFuseStreamFactory() - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
Get the FuseStreamFactory instance member that is for creating FuseFileStream.
getFuseVersion() - Method in class alluxio.fuse.options.MountOptions
 
getFuture() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient.NoDataReadStreamObserver
 
getGainPrimacyTime() - Method in class alluxio.wire.MasterInfo
 
getGcExecutor() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGcIntervalMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGetActionInfoMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
getGetAllDatabasesMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetAllMasterStatusMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetAllTablesMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetAllWorkerHealthMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetBackupStatusMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getGetBlockInfoMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGetBlockMasterInfoMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGetCapacityBytesMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGetCmdStatusDetailedMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetCmdStatusMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetConfigHashMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
getGetConfigReportMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getGetConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
getGetDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetFileInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
 
getGetFileInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
getGetFilePathMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetJobProgressMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetJobServiceSummaryMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetJobStatusDetailedMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetJobStatusMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getGetLostWorkerListMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGetMasterIdMethod() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
 
getGetMasterIdMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
getGetMasterInfoMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getGetMetricsMethod() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
 
getGetMountIdMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetMountIdMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
getGetMountTableMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetNewBlockIdForFileMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetNodeStateMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getGetPartitionColumnStatisticsMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetPinnedFileIdsMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
getGetPolicyStatusMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
getGetQuorumInfoMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getGetServiceVersionMethod() - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
 
getGetStateLockHoldersMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetStatusMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getGetStatusMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getGetTableColumnStatisticsMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetTableMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetTransferLeaderMessageMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getGetTransformJobInfoMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getGetUfsInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
 
getGetUfsInfoMethod() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
getGetUsedBytesMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGetWorkerIdMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getGetWorkerInfoListMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGetWorkerLostStorageMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGetWorkerReportMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getGid() - Method in interface alluxio.fuse.auth.AuthPolicy
 
getGid(String) - Method in interface alluxio.fuse.auth.AuthPolicy
Gets the gid based on the auth policy and file group.
getGid() - Method in class alluxio.fuse.auth.CustomAuthPolicy
 
getGid() - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
getGid() - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
 
getGid(String) - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
 
getGid() - Method in class alluxio.fuse.file.CreateFileStatus
 
getGidFromGroupName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the gid of the given group.
getGidFromUserName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the primary gid of the given user.
getGlobalStorageTierAssoc() - Method in interface alluxio.master.block.BlockMaster
 
getGlobalStorageTierAssoc() - Method in class alluxio.master.block.DefaultBlockMaster
 
getGraceCycleSleepMs() - Method in class alluxio.master.StateLockOptions
 
getGraceCycleTimeoutMs() - Method in class alluxio.master.StateLockOptions
 
getGraceCycleTryMs() - Method in class alluxio.master.StateLockOptions
 
getGraceMode() - Method in class alluxio.master.StateLockOptions
 
getGroup() - Method in class alluxio.client.file.options.OutStreamOptions
 
getGroup() - Method in class alluxio.client.file.URIStatus
 
getGroup() - Method in class alluxio.grpc.FileInfo.Builder
optional string group = 17;
getGroup() - Method in class alluxio.grpc.FileInfo
optional string group = 17;
getGroup() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string group = 17;
getGroup() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string group = 4;
getGroup() - Method in class alluxio.grpc.SetAttributePOptions
optional string group = 4;
getGroup() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional string group = 4;
getGroup() - Method in class alluxio.grpc.UfsStatus.Builder
optional string group = 5;
getGroup() - Method in class alluxio.grpc.UfsStatus
optional string group = 5;
getGroup() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string group = 5;
getGroup() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getGroup() - Method in class alluxio.master.file.meta.Inode
 
getGroup() - Method in interface alluxio.master.file.meta.InodeView
 
getGroup() - Method in class alluxio.master.file.meta.MutableInode
 
getGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
getGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string group = 3;
getGroup() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string group = 3;
getGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
getGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string group = 9;
getGroup() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string group = 9;
getGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
getGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string group = 15;
getGroup() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string group = 15;
getGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
getGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string group = 7;
getGroup() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string group = 7;
getGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string group = 10;
getGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string group = 10;
getGroup() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string group = 10;
getGroup() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getGroup() - Method in class alluxio.underfs.options.CreateOptions
 
getGroup() - Method in class alluxio.underfs.options.MkdirsOptions
 
getGroup() - Method in class alluxio.underfs.UfsStatus
Gets the group of the given path.
getGroup(UserState, AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
 
getGroup() - Method in class alluxio.util.webui.UIFileInfo
Gets group.
getGroup() - Method in class alluxio.wire.FileInfo
 
getGroupActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActions(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsCount() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsOrBuilder(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupActionsOrBuilderList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
getGroupBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits groupBits = 2;
getGroupBits() - Method in class alluxio.grpc.PMode
required .alluxio.grpc.Bits groupBits = 2;
getGroupBits() - Method in interface alluxio.grpc.PModeOrBuilder
required .alluxio.grpc.Bits groupBits = 2;
getGroupBits() - Method in class alluxio.security.authorization.Mode
 
getGroupBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string group = 17;
getGroupBytes() - Method in class alluxio.grpc.FileInfo
optional string group = 17;
getGroupBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string group = 17;
getGroupBytes() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string group = 4;
getGroupBytes() - Method in class alluxio.grpc.SetAttributePOptions
optional string group = 4;
getGroupBytes() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional string group = 4;
getGroupBytes() - Method in class alluxio.grpc.UfsStatus.Builder
optional string group = 5;
getGroupBytes() - Method in class alluxio.grpc.UfsStatus
optional string group = 5;
getGroupBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string group = 5;
getGroupBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
getGroupBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string group = 3;
getGroupBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string group = 3;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string group = 9;
getGroupBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string group = 9;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
getGroupBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string group = 15;
getGroupBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string group = 15;
getGroupBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
getGroupBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string group = 7;
getGroupBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string group = 7;
getGroupBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string group = 10;
getGroupBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string group = 10;
getGroupBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string group = 10;
getGroupFromGrpcClient(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
 
getGroupName(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the primary group name from the user name.
getGroupName(long) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the group name from the group id.
getGroups(String) - Method in class alluxio.security.group.CachedGroupMapping
 
getGroups(String) - Method in interface alluxio.security.group.GroupMappingService
Gets all various group memberships of a given user.
getGroups(String) - Method in class alluxio.security.group.provider.IdentityUserGroupsMapping
Returns list of groups for a user.
getGroups(String) - Method in class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
Returns list of groups for a user.
getGroups(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
Using CachedGroupMapping to get the group list of a user.
getGroupsForUserCommand(String) - Static method in class alluxio.util.ShellUtils
Gets a Unix command to get a given user's groups list.
getGRpcBindAddress() - Method in class alluxio.worker.DataServerFactory
Get gRPC bind address.
getGrpcFileInfo(String, long) - Method in class alluxio.worker.dora.PagedDoraWorker
 
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
getGrpcMasterAddress(MasterInquireClient) - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
Gets the master address the client makes gRPC request to.
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
 
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
 
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
 
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
 
getHadoopVersion() - Method in class alluxio.cli.hdfs.HdfsVersionValidationTask
 
getHandler() - Method in class alluxio.metrics.sink.MetricsServlet
Gets the ServletContextHandler of the metrics servlet.
getHandler() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
Gets the ServletContextHandler of the metrics servlet.
getHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool has_direct_children_loaded = 13;
getHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool has_direct_children_loaded = 13;
getHasDirectChildrenLoaded() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool has_direct_children_loaded = 13;
getHash() - Method in class alluxio.master.meta.PathPropertiesView
 
getHdfsConfPaths() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
 
getHeadDelay() - Method in class alluxio.util.executor.ControllableQueue
 
getHeader(String) - Method in class alluxio.proxy.s3.S3Handler
get specified HTTP header value of this request.
getHeader(String) - Method in class alluxio.worker.s3.S3NettyHandler
get specified HTTP header value of this request.
getHeaderOrDefault(String, String) - Method in class alluxio.proxy.s3.S3Handler
get specified HTTP header with a default if not exist.
getHeaderOrDefault(String, String) - Method in class alluxio.worker.s3.S3NettyHandler
get specified HTTP header with a default if not exist.
getHeadValue() - Method in class alluxio.util.executor.ControllableQueue
 
getHeartbeatMethod() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
 
getHelp() - Method in class alluxio.fuse.options.FuseCliOptions
 
getHigh() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
getHigh() - Method in class alluxio.grpc.table.Range
optional .alluxio.grpc.table.Value high = 2;
getHigh() - Method in interface alluxio.grpc.table.RangeOrBuilder
optional .alluxio.grpc.table.Value high = 2;
getHighBuilder() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
getHighestTierAlias() - Method in class alluxio.wire.MasterWebUIBrowse
Gets highest tier alias.
getHighOrBuilder() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
getHighOrBuilder() - Method in class alluxio.grpc.table.Range
optional .alluxio.grpc.table.Value high = 2;
getHighOrBuilder() - Method in interface alluxio.grpc.table.RangeOrBuilder
optional .alluxio.grpc.table.Value high = 2;
getHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
getHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData
optional .alluxio.grpc.table.Date high_value = 2;
getHighValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Date high_value = 2;
getHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
getHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional .alluxio.grpc.table.Decimal high_value = 2;
getHighValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Decimal high_value = 2;
getHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double high_value = 2;
getHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional double high_value = 2;
getHighValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional double high_value = 2;
getHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 high_value = 2;
getHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 high_value = 2;
getHighValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 high_value = 2;
getHighValueBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
getHighValueBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
getHighValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
getHighValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData
optional .alluxio.grpc.table.Date high_value = 2;
getHighValueOrBuilder() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Date high_value = 2;
getHighValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
getHighValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional .alluxio.grpc.table.Decimal high_value = 2;
getHighValueOrBuilder() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Decimal high_value = 2;
getHighWaterMark() - Method in class alluxio.master.metastore.caching.CacheConfiguration
 
getHiveCacheContext() - Method in class alluxio.client.file.CacheContext
 
getHost() - Method in class alluxio.cli.LogLevel.TargetInfo
 
getHost() - Method in class alluxio.grpc.NetAddress.Builder
optional string host = 1;
getHost() - Method in class alluxio.grpc.NetAddress
optional string host = 1;
getHost() - Method in interface alluxio.grpc.NetAddressOrBuilder
optional string host = 1;
getHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string host = 1;
getHost() - Method in class alluxio.grpc.WorkerNetAddress
optional string host = 1;
getHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string host = 1;
getHost() - Method in class alluxio.uri.SingleMasterAuthority
 
getHost() - Method in class alluxio.util.webui.NodeInfo
Gets host.
getHost() - Method in class alluxio.wire.Address
 
getHost() - Method in class alluxio.wire.WorkerNetAddress
 
getHost() - Method in class alluxio.worker.http.HttpRequestUri
Get the host name of the request URI.
getHostBytes() - Method in class alluxio.grpc.NetAddress.Builder
optional string host = 1;
getHostBytes() - Method in class alluxio.grpc.NetAddress
optional string host = 1;
getHostBytes() - Method in interface alluxio.grpc.NetAddressOrBuilder
optional string host = 1;
getHostBytes() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string host = 1;
getHostBytes() - Method in class alluxio.grpc.WorkerNetAddress
optional string host = 1;
getHostBytes() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string host = 1;
getHostName() - Method in class alluxio.grpc.GrpcServerAddress
 
getHostname() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional string hostname = 4;
getHostname() - Method in class alluxio.grpc.JobWorkerHealth
optional string hostname = 4;
getHostname() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional string hostname = 4;
getHostname() - Method in class alluxio.job.wire.JobWorkerHealth
 
getHostname() - Method in class alluxio.master.LocalAlluxioCluster
 
getHostname() - Method in class alluxio.master.LocalAlluxioJobCluster
 
getHostname() - Method in class alluxio.multi.process.MasterNetAddress
 
getHostName() - Method in class alluxio.shell.ScpCommand
Returns the remote target hostname.
getHostName() - Method in class alluxio.shell.SshCommand
Returns the remote target hostname.
getHostname() - Method in class alluxio.wire.BackupStatus
 
getHostnameBytes() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional string hostname = 4;
getHostnameBytes() - Method in class alluxio.grpc.JobWorkerHealth
optional string hostname = 4;
getHostnameBytes() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional string hostname = 4;
getHostNameKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the key of connect hostname.
getHostNameKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of connect hostname.
getHosts() - Method in class alluxio.cli.bundler.CollectInfo
Finds all hosts in the Alluxio cluster.
getHttpMethod() - Method in class alluxio.worker.s3.S3NettyHandler
get HTTP verb of this request.
getHttpResponse() - Method in class alluxio.worker.http.HttpResponseContext
Get the http response.
getHTTPVerb() - Method in class alluxio.proxy.s3.S3Handler
get HTTP verb of this request.
getId() - Method in class alluxio.client.file.FileSystemContext
 
getId() - Method in class alluxio.fuse.CreateFileEntry
 
getId() - Method in class alluxio.fuse.file.FuseFileEntry
 
getId() - Method in class alluxio.fuse.OpenFileEntry
 
getId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
optional int64 id = 1;
getId() - Method in interface alluxio.grpc.GetNewBlockIdForFilePResponseOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.JobInfo
optional int64 id = 1;
getId() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.PolicyInfo
optional int64 id = 1;
getId() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
optional int64 id = 1;
getId() - Method in interface alluxio.grpc.RegisterJobWorkerPResponseOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional uint32 id = 1;
getId() - Method in class alluxio.grpc.table.FieldSchema
optional uint32 id = 1;
getId() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional uint32 id = 1;
getId() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.WorkerInfo
optional int64 id = 1;
getId() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.grpc.WriteRequestCommand.Builder
The block ID or UFS file ID.
getId() - Method in class alluxio.grpc.WriteRequestCommand
The block ID or UFS file ID.
getId() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
The block ID or UFS file ID.
getId() - Method in class alluxio.job.MasterWorkerInfo
 
getId() - Method in class alluxio.job.plan.meta.PlanInfo
 
getId() - Method in interface alluxio.job.wire.JobInfo
 
getId() - Method in class alluxio.job.wire.PlanInfo
 
getId() - Method in class alluxio.job.wire.TaskInfo
 
getId() - Method in class alluxio.job.wire.WorkflowInfo
 
getId() - Method in class alluxio.master.block.meta.MasterWorkerInfo
No locking required.
getId() - Method in class alluxio.master.file.meta.Edge
 
getId() - Method in class alluxio.master.file.meta.Inode
 
getId() - Method in interface alluxio.master.file.meta.InodeView
 
getId() - Method in class alluxio.master.file.meta.MutableInode
 
getId() - Method in class alluxio.master.file.PersistJob
 
getId() - Method in enum alluxio.master.journal.checkpoint.CheckpointType
 
getId() - Method in class alluxio.master.meta.JobMasterInfo
 
getId() - Method in class alluxio.master.meta.MasterInfo
 
getId(Address) - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
Returns a master id for a master address.
getId(Address) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Returns a master id for a master address.
getId() - Method in class alluxio.master.metastore.BlockMetaStore.Block
 
getId() - Method in enum alluxio.network.protocol.RPCMessage.Type
Returns the int identifier of the type.
getId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
The block ID or UFS file ID.
getId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
The block ID or UFS file ID.
getId() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
The block ID or UFS file ID.
getId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 id = 2;
getId() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 id = 2;
getId() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 id = 2;
getId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.NewBlockEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.NewBlockEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.PersistDirectoryEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.SetAclEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional int64 id = 1;
getId() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional int64 id = 1;
getId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 id = 1;
getId() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 id = 1;
getId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 id = 1;
getID() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets id.
getId() - Method in class alluxio.util.webui.UIFileInfo
Gets id.
getId() - Method in class alluxio.util.webui.UIMasterInfo
Get id.
getId() - Method in class alluxio.wire.BlockReadRequest
 
getId() - Method in class alluxio.wire.MasterInfo
 
getId() - Method in class alluxio.wire.WorkerInfo
 
getId(WorkerNetAddress) - Method in class alluxio.worker.block.BlockMasterClient
Returns a worker id for a workers net address.
getId() - Method in class alluxio.worker.grpc.WriteRequest
 
getId() - Method in class alluxio.worker.netty.ReadRequest
 
getIdentifier() - Method in class alluxio.client.file.cache.CacheUsage.DirPartition
 
getIdentifier() - Method in class alluxio.client.file.cache.CacheUsage.FilePartition
 
getIdentifier() - Method in interface alluxio.client.file.cache.CacheUsage.PartitionDescriptor
Gets an identifier of the partition.
getIdentifier() - Method in class alluxio.client.file.cache.CacheUsage.ScopePartition
 
getIdentifier() - Method in class alluxio.grpc.WorkerIdentity.Builder
exactly how this byte sequence is interpreted depends on the version of its definition
getIdentifier() - Method in class alluxio.grpc.WorkerIdentity
exactly how this byte sequence is interpreted depends on the version of its definition
getIdentifier() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
exactly how this byte sequence is interpreted depends on the version of its definition
getIdentifier() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
 
getIdentifier() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
 
getIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignoreClusterConf = 2;
getIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions
optional bool ignoreClusterConf = 2;
getIgnoreClusterConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
optional bool ignoreClusterConf = 2;
getIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignorePathConf = 3;
getIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions
optional bool ignorePathConf = 3;
getIgnorePathConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
optional bool ignorePathConf = 3;
getIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional bool ignore_sync_errors = 6;
getIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional bool ignore_sync_errors = 6;
getIgnoreSyncErrors() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional bool ignore_sync_errors = 6;
getImpersonationAuthenticator() - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
getImpersonationUser(Subject, AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticationUtils
 
getIn() - Method in class alluxio.fuse.OpenFileEntry
Gets the opened input stream for this open file entry.
getInAlluxio() - Method in class alluxio.util.webui.UIFileInfo
Gets in alluxio.
getInAlluxioFileNum() - Method in class alluxio.wire.MasterWebUIData
Gets in alluxio file num.
getInAlluxioFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getInAlluxioFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getInAlluxioPercentage() - Method in class alluxio.client.file.URIStatus
 
getInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inAlluxioPercentage = 24;
getInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo
optional int32 inAlluxioPercentage = 24;
getInAlluxioPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 inAlluxioPercentage = 24;
getInAlluxioPercentage() - Method in class alluxio.util.webui.UIFileInfo
Gets in alluxio percentage.
getInAlluxioPercentage() - Method in class alluxio.wire.FileInfo
 
getIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool includeRealContentHash = 5;
getIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions
optional bool includeRealContentHash = 5;
getIncludeRealContentHash() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional bool includeRealContentHash = 5;
getInconsistentPaths(int) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
getInconsistentPaths(int) - Method in class alluxio.grpc.CheckConsistencyPResponse
repeated string inconsistentPaths = 1;
getInconsistentPaths(int) - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
repeated string inconsistentPaths = 1;
getInconsistentPathsBytes(int) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
getInconsistentPathsBytes(int) - Method in class alluxio.grpc.CheckConsistencyPResponse
repeated string inconsistentPaths = 1;
getInconsistentPathsBytes(int) - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
repeated string inconsistentPaths = 1;
getInconsistentPathsCount() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
getInconsistentPathsCount() - Method in class alluxio.grpc.CheckConsistencyPResponse
repeated string inconsistentPaths = 1;
getInconsistentPathsCount() - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
repeated string inconsistentPaths = 1;
getInconsistentPathsList() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
getInconsistentPathsList() - Method in class alluxio.grpc.CheckConsistencyPResponse
repeated string inconsistentPaths = 1;
getInconsistentPathsList() - Method in interface alluxio.grpc.CheckConsistencyPResponseOrBuilder
repeated string inconsistentPaths = 1;
getIncreasingByteArray(int) - Static method in class alluxio.util.io.BufferUtils
Gets an increasing sequence of bytes starting at zero.
getIncreasingByteArray(int, int) - Static method in class alluxio.util.io.BufferUtils
Gets an increasing sequence of bytes starting with the given value.
getIncreasingByteBuffer(int) - Static method in class alluxio.util.io.BufferUtils
Gets a ByteBuffer containing an increasing sequence of bytes starting at zero.
getIncreasingByteBuffer(int, int) - Static method in class alluxio.util.io.BufferUtils
Gets a ByteBuffer containing an increasing sequence of bytes starting at the given value.
getIndex() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getInfo(long) - Method in class alluxio.client.block.BlockStoreClient
Gets the block info of a block, if it exists.
getInfo(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfo(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfo(int) - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfo(Boolean) - Method in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
getInfo(Boolean) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
getInfo(Boolean) - Method in class alluxio.proxy.AlluxioProxyRestServiceHandler
 
getInfo(Boolean) - Method in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
getInfo() - Method in class alluxio.worker.dora.OpenFileHandle
Get info of this handle.
getInfoBuilder(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoBuilderList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoCount() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoCount() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoCount() - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoList() - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoOrBuilder(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoOrBuilder(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoOrBuilder(int) - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoOrBuilderList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoOrBuilderList() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfoOrBuilderList() - Method in interface alluxio.grpc.table.GetTransformJobInfoPResponseOrBuilder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
getInfos(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfos(int) - Method in class alluxio.grpc.GetActionInfoResponse
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfos(int) - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosBuilder(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosBuilderList() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosCount() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosCount() - Method in class alluxio.grpc.GetActionInfoResponse
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosCount() - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosList() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosList() - Method in class alluxio.grpc.GetActionInfoResponse
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosList() - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosOrBuilder(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosOrBuilder(int) - Method in class alluxio.grpc.GetActionInfoResponse
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosOrBuilder(int) - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosOrBuilderList() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosOrBuilderList() - Method in class alluxio.grpc.GetActionInfoResponse
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfosOrBuilderList() - Method in interface alluxio.grpc.GetActionInfoResponseOrBuilder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
getInfoTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
 
getInitialBytes() - Method in class alluxio.worker.block.CreateBlockOptions
 
getInitialDelayMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getInitiated() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
 
getInMemoryFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getInMemoryFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getInMemoryPercentage() - Method in class alluxio.client.file.URIStatus
 
getInMemoryPercentage() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inMemoryPercentage = 25;
getInMemoryPercentage() - Method in class alluxio.grpc.FileInfo
optional int32 inMemoryPercentage = 25;
getInMemoryPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 inMemoryPercentage = 25;
getInMemoryPercentage() - Method in class alluxio.wire.FileInfo
 
getInode() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodeCount() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getInodeCount() - Method in interface alluxio.master.file.FileSystemMaster
Get the total inode count.
getInodeCount() - Method in class alluxio.master.file.meta.InodeTree
 
getInodeCount() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryIdGeneratorOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
getInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
getInodeExpiries() - Method in class alluxio.master.file.meta.TtlBucket
Get collection of inode to its left ttl process retry attempts.
getInodeFile() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
getInodeIds() - Method in class alluxio.master.file.meta.TtlBucket
 
getInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTime() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeLastModificationTimeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
getInodeList() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodeLockManager() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
getInodeLockManager() - Method in interface alluxio.master.file.meta.InodeLockList
 
getInodeLockManager() - Method in class alluxio.master.file.meta.InodeTree
 
getInodeLockManager() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
getInodeOrNull() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInodePathList() - Method in class alluxio.master.file.meta.LockedInodePathList
get the associated inodePathList.
getInodePathString(InodeView) - Method in interface alluxio.master.metastore.InodeStore
Traverses the inode path starting from the given inode up to the root.
getInodeStoreFactory() - Method in class alluxio.master.CoreMasterContext
 
getInodeStoreFactory(String) - Static method in class alluxio.master.MasterUtils
 
getInodeViewList() - Method in class alluxio.master.file.meta.LockedInodePath
 
getInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string input_format = 2;
getInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string input_format = 2;
getInputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string input_format = 2;
getInputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string input_format = 2;
getInputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string input_format = 2;
getInputFormatBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string input_format = 2;
getInputStream() - Method in class alluxio.proxy.s3.S3Handler
retrieve inputstream from incoming request.
getInputStream(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
getInstance() - Method in class alluxio.grpc.Metric.Builder
optional string instance = 1;
getInstance() - Method in class alluxio.grpc.Metric
optional string instance = 1;
getInstance() - Method in interface alluxio.grpc.MetricOrBuilder
optional string instance = 1;
getInstance() - Static method in class alluxio.jnifuse.utils.NativeLibraryLoader
Get a reference to the NativeLibraryLoader.
getInstance() - Static method in class alluxio.master.scheduler.Scheduler
Get the singleton instance of Scheduler.
getInstance(AlluxioConfiguration) - Static method in class alluxio.membership.AlluxioEtcdClient
Get the singleton instance of AlluxioEtcdClient.
getInstance() - Static method in class alluxio.proxy.s3.MultipartUploadCleaner
 
getInstanceBytes() - Method in class alluxio.grpc.Metric.Builder
optional string instance = 1;
getInstanceBytes() - Method in class alluxio.grpc.Metric
optional string instance = 1;
getInstanceBytes() - Method in interface alluxio.grpc.MetricOrBuilder
optional string instance = 1;
getInstanceType() - Method in class alluxio.metrics.Metric
 
getInstanceType() - Method in class alluxio.metrics.MetricsFilter
 
getInStream(URIStatus, Protocol.OpenUfsBlockOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Get a stream to read the data from dora cache cluster.
getInStream(Integer) - Method in class alluxio.StreamCache
 
getInt(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the integer representation of the value for the given key.
getInt(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the integer representation of the value for the given key.
getInt(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getInt(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getIntArg(CommandLine, Option, int) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the value of an option from the command line.
getInterval() - Method in class alluxio.util.WaitForOptions
 
getIntervals() - Method in class alluxio.master.predicate.interval.IntervalSet
 
getInvalidPathError() - Method in class alluxio.wire.MasterWebUIBrowse
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.MasterWebUILogs
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.WorkerWebUILogs
Gets invalid path error.
getInvalidPathException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets invalid path exception.
getIOBytes() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
getIOBytes() - Method in class alluxio.stress.worker.WorkerBenchSummary
 
getIOBytes() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getIOMBps() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
getIOMBps() - Method in class alluxio.stress.worker.WorkerBenchSummary
 
getIpAddress() - Static method in class alluxio.security.authentication.ClientContextServerInjector
 
getIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool isAtomicWrite = 16;
getIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions
optional bool isAtomicWrite = 16;
getIsAtomicWrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool isAtomicWrite = 16;
getIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_cacheable = 17;
getIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_cacheable = 17;
getIsCacheable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_cacheable = 17;
getIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_completed = 18;
getIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_completed = 18;
getIsCompleted() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_completed = 18;
getIsDefault() - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefault = 5;
getIsDefault() - Method in class alluxio.grpc.PAcl
optional bool isDefault = 5;
getIsDefault() - Method in class alluxio.grpc.PAclEntry.Builder
optional bool isDefault = 4;
getIsDefault() - Method in class alluxio.grpc.PAclEntry
optional bool isDefault = 4;
getIsDefault() - Method in interface alluxio.grpc.PAclEntryOrBuilder
optional bool isDefault = 4;
getIsDefault() - Method in interface alluxio.grpc.PAclOrBuilder
optional bool isDefault = 5;
getIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isDefault = 7;
getIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional bool isDefault = 7;
getIsDefault() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional bool isDefault = 7;
getIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional bool isDefault = 4;
getIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry
optional bool isDefault = 4;
getIsDefault() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
optional bool isDefault = 4;
getIsDefaultEmpty() - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefaultEmpty = 6;
getIsDefaultEmpty() - Method in class alluxio.grpc.PAcl
optional bool isDefaultEmpty = 6;
getIsDefaultEmpty() - Method in interface alluxio.grpc.PAclOrBuilder
optional bool isDefaultEmpty = 6;
getIsDirectory() - Method in class alluxio.grpc.UfsStatus.Builder
optional bool is_directory = 2;
getIsDirectory() - Method in class alluxio.grpc.UfsStatus
optional bool is_directory = 2;
getIsDirectory() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional bool is_directory = 2;
getIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_directory = 3;
getIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_directory = 3;
getIsDirectory() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_directory = 3;
getIsDirectory() - Method in class alluxio.util.webui.UIFileInfo
Gets is directory.
getIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isEmpty = 8;
getIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional bool isEmpty = 8;
getIsEmpty() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional bool isEmpty = 8;
getIsLeader() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional bool isLeader = 3;
getIsLeader() - Method in class alluxio.grpc.QuorumServerInfo
optional bool isLeader = 3;
getIsLeader() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional bool isLeader = 3;
getIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
directory only
getIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode
directory only
getIsMountPoint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
directory only
getIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool isMultipartUpload = 2;
getIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions
optional bool isMultipartUpload = 2;
getIsMultipartUpload() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
optional bool isMultipartUpload = 2;
getIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_pinned = 9;
getIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_pinned = 9;
getIsPinned() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_pinned = 9;
getIsRetryable() - Method in class alluxio.grpc.RetryInfo.Builder
optional bool isRetryable = 1;
getIsRetryable() - Method in class alluxio.grpc.RetryInfo
optional bool isRetryable = 1;
getIsRetryable() - Method in interface alluxio.grpc.RetryInfoOrBuilder
optional bool isRetryable = 1;
getIsScanning() - Method in class alluxio.grpc.PolicyStatus.Builder
optional bool isScanning = 11;
getIsScanning() - Method in class alluxio.grpc.PolicyStatus
optional bool isScanning = 11;
getIsScanning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional bool isScanning = 11;
getIsSkip() - Method in class alluxio.grpc.RouteFailure.Builder
optional bool is_skip = 5;
getIsSkip() - Method in class alluxio.grpc.RouteFailure
optional bool is_skip = 5;
getIsSkip() - Method in interface alluxio.grpc.RouteFailureOrBuilder
optional bool is_skip = 5;
getIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional bool isThrowable = 2;
getIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader
optional bool isThrowable = 2;
getIsThrowable() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
optional bool isThrowable = 2;
getIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
True if the partial listing was truncated.
getIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse
True if the partial listing was truncated.
getIsTruncated() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
True if the partial listing was truncated.
getIsttfb() - Method in class alluxio.stress.cli.Benchmark.ProfileInput
 
getItems() - Method in class alluxio.underfs.UfsLoadResult
 
getItemsCount() - Method in class alluxio.underfs.UfsLoadResult
 
getJavaVersion() - Static method in class alluxio.util.CommonUtils
 
getJniLibraryExtension() - Static method in class alluxio.jnifuse.utils.Environment
 
getJniLibraryFileName(String) - Static method in class alluxio.jnifuse.utils.Environment
 
getJniLibraryName(String) - Static method in class alluxio.jnifuse.utils.Environment
 
getJob() - Method in class alluxio.scheduler.job.Task
Get the job this task belongs to.
getJobConfig() - Method in class alluxio.cli.fs.command.job.JobAttempt
Get job config.
getJobConfig() - Method in class alluxio.grpc.RunPRequest.Builder
optional bytes jobConfig = 1;
getJobConfig() - Method in class alluxio.grpc.RunPRequest
optional bytes jobConfig = 1;
getJobConfig() - Method in interface alluxio.grpc.RunPRequestOrBuilder
optional bytes jobConfig = 1;
getJobConfig() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes jobConfig = 3;
getJobConfig() - Method in class alluxio.grpc.RunTaskCommand
optional bytes jobConfig = 3;
getJobConfig() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional bytes jobConfig = 3;
getJobConfig() - Method in class alluxio.job.plan.batch.BatchedJobDefinition.BatchedJobTask
 
getJobConfig() - Method in class alluxio.job.plan.meta.PlanInfo
 
getJobConfig() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Get job config.
getJobConfigClass() - Method in class alluxio.job.plan.batch.BatchedJobDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.migrate.MigrateDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.NoopPlanDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.persist.PersistDefinition
 
getJobConfigClass() - Method in interface alluxio.job.plan.PlanDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.replicate.MoveDefinition
 
getJobConfigClass() - Method in class alluxio.job.plan.stress.StressBenchDefinition
 
getJobConfigs() - Method in class alluxio.job.plan.BatchedJobConfig
 
getJobControlId() - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.CmdStatusBlock
optional int64 jobControlId = 1;
getJobControlId() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.CmdSummary
optional int64 jobControlId = 1;
getJobControlId() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
optional int64 jobControlId = 1;
getJobControlId() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest
optional int64 jobControlId = 1;
getJobControlId() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.SubmitResponse.Builder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.grpc.SubmitResponse
optional int64 jobControlId = 1;
getJobControlId() - Method in interface alluxio.grpc.SubmitResponseOrBuilder
optional int64 jobControlId = 1;
getJobControlId() - Method in class alluxio.job.wire.CmdStatusBlock
Get job control ID of the command.
getJobControlId() - Method in class alluxio.master.job.common.CmdInfo
Get job control Id.
getJobDefinition(T) - Method in enum alluxio.job.plan.PlanDefinitionRegistry
Gets the job definition from the job configuration.
getJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescription() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescription() - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescription() - Method in class alluxio.grpc.StopJobPRequest
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescription() - Method in interface alluxio.grpc.StopJobPRequestOrBuilder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionBuilder() - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionOrBuilder() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionOrBuilder() - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionOrBuilder() - Method in class alluxio.grpc.StopJobPRequest
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobDescriptionOrBuilder() - Method in interface alluxio.grpc.StopJobPRequestOrBuilder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
getJobError() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string job_error = 6;
getJobError() - Method in class alluxio.grpc.table.TransformJobInfo
optional string job_error = 6;
getJobError() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string job_error = 6;
getJobErrorBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string job_error = 6;
getJobErrorBytes() - Method in class alluxio.grpc.table.TransformJobInfo
optional string job_error = 6;
getJobErrorBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string job_error = 6;
getJobId() - Method in class alluxio.grpc.CancelPRequest.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.CancelPRequest
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.CancelTaskCommand
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.GetJobStatusPRequest
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.JobProgress
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.JobStatusBlock
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.RunPResponse.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.RunPResponse
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.RunPResponseOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.RunTaskCommand
optional int64 jobId = 1;
getJobId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional int64 jobId = 1;
getJobId() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
optional string jobId = 1;
getJobId() - Method in class alluxio.grpc.SubmitJobPResponse
optional string jobId = 1;
getJobId() - Method in interface alluxio.grpc.SubmitJobPResponseOrBuilder
optional string jobId = 1;
getJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
optional int64 job_id = 1;
getJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
optional int64 job_id = 1;
getJobId() - Method in interface alluxio.grpc.table.GetTransformJobInfoPRequestOrBuilder
optional int64 job_id = 1;
getJobId() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional int64 job_id = 4;
getJobId() - Method in class alluxio.grpc.table.TransformJobInfo
optional int64 job_id = 4;
getJobId() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional int64 job_id = 4;
getJobId() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
optional int64 job_id = 1;
getJobId() - Method in class alluxio.grpc.table.TransformTablePResponse
optional int64 job_id = 1;
getJobId() - Method in interface alluxio.grpc.table.TransformTablePResponseOrBuilder
optional int64 job_id = 1;
getJobId() - Method in class alluxio.job.RunTaskContext
 
getJobId() - Method in class alluxio.job.SelectExecutorsContext
 
getJobId() - Method in class alluxio.job.wire.SimpleJobStatusBlock
Get job id.
getJobId() - Method in class alluxio.job.wire.TaskInfo
 
getJobId() - Method in class alluxio.master.job.AbstractJob
 
getJobId() - Method in class alluxio.master.job.plan.PlanCoordinator
 
getJobId() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Returns the job Id.
getJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string job_id = 8;
getJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string job_id = 8;
getJobId() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string job_id = 8;
getJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string job_id = 7;
getJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required string job_id = 7;
getJobId() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required string job_id = 7;
getJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string job_id = 8;
getJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string job_id = 8;
getJobId() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string job_id = 8;
getJobId() - Method in interface alluxio.scheduler.job.Job
 
getJobIdBytes() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
optional string jobId = 1;
getJobIdBytes() - Method in class alluxio.grpc.SubmitJobPResponse
optional string jobId = 1;
getJobIdBytes() - Method in interface alluxio.grpc.SubmitJobPResponseOrBuilder
optional string jobId = 1;
getJobIdBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string job_id = 8;
getJobIdBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string job_id = 8;
getJobIdBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string job_id = 8;
getJobIdBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string job_id = 7;
getJobIdBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required string job_id = 7;
getJobIdBytes() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required string job_id = 7;
getJobIdBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string job_id = 8;
getJobIdBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string job_id = 8;
getJobIdBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string job_id = 8;
getJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions.Builder
optional bool jobIdOnly = 3;
getJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions
optional bool jobIdOnly = 3;
getJobIdOnly() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
optional bool jobIdOnly = 3;
getJobIds(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 1;
getJobIds(int) - Method in class alluxio.grpc.ListAllPResponse
repeated int64 jobIds = 1;
getJobIds(int) - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated int64 jobIds = 1;
getJobIdsCount() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 1;
getJobIdsCount() - Method in class alluxio.grpc.ListAllPResponse
repeated int64 jobIds = 1;
getJobIdsCount() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated int64 jobIds = 1;
getJobIdsList() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 1;
getJobIdsList() - Method in class alluxio.grpc.ListAllPResponse
repeated int64 jobIds = 1;
getJobIdsList() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated int64 jobIds = 1;
getJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfo() - Method in interface alluxio.grpc.GetJobStatusDetailedPResponseOrBuilder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfo() - Method in interface alluxio.grpc.GetJobStatusPResponseOrBuilder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoBuilder() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoOrBuilder() - Method in interface alluxio.grpc.GetJobStatusDetailedPResponseOrBuilder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoOrBuilder() - Method in class alluxio.grpc.GetJobStatusPResponse
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfoOrBuilder() - Method in interface alluxio.grpc.GetJobStatusPResponseOrBuilder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
getJobInfos(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfos(int) - Method in class alluxio.grpc.ListAllPResponse
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfos(int) - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosBuilder(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosBuilderList() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosCount() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosCount() - Method in class alluxio.grpc.ListAllPResponse
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosCount() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosList() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosList() - Method in class alluxio.grpc.ListAllPResponse
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosList() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosOrBuilder(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosOrBuilder(int) - Method in class alluxio.grpc.ListAllPResponse
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosOrBuilder(int) - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosOrBuilderList() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosOrBuilderList() - Method in class alluxio.grpc.ListAllPResponse
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobInfosOrBuilderList() - Method in interface alluxio.grpc.ListAllPResponseOrBuilder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
getJobMaster() - Method in class alluxio.master.AlluxioJobMasterProcess
 
getJobMasterAddress() - Method in class alluxio.client.job.JobContext
 
getJobMasterClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getJobMasterEmbeddedJournalAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
getJobMasterHostNotConfiguredMessage(String) - Static method in class alluxio.util.ConfigurationUtils
Returns a unified message for cases when the job master hostname cannot be determined.
getJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional int64 jobMasterId = 1;
getJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest
optional int64 jobMasterId = 1;
getJobMasterId() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
optional int64 jobMasterId = 1;
GetJobMasterIdPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobMasterIdPOptions
GetJobMasterIdPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobMasterIdPOptions
GetJobMasterIdPOptionsOrBuilder - Interface in alluxio.grpc
 
GetJobMasterIdPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobMasterIdPRequest
GetJobMasterIdPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobMasterIdPRequest
GetJobMasterIdPRequestOrBuilder - Interface in alluxio.grpc
 
GetJobMasterIdPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobMasterIdPResponse
GetJobMasterIdPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobMasterIdPResponse
GetJobMasterIdPResponseOrBuilder - Interface in alluxio.grpc
 
getJobMasterRpcAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets the RPC addresses of all job masters based on the configuration.
getJobMasterStatus(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatus(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatus(int) - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusBuilder(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusBuilderList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusCount() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusCount() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusCount() - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusList() - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusOrBuilder(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusOrBuilder(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusOrBuilder(int) - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusOrBuilderList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusOrBuilderList() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMasterStatusOrBuilderList() - Method in interface alluxio.grpc.GetAllMasterStatusPResponseOrBuilder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
getJobMetaStore() - Method in class alluxio.master.scheduler.Scheduler
Get job meta store.
getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.client.file.DelegatingFileSystem
 
getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in interface alluxio.client.file.FileSystem
Get progress of a job.
getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in interface alluxio.client.file.FileSystemMasterClient
Get progress of a job.
getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getJobProgress(int) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgress(int) - Method in class alluxio.grpc.CmdProgress
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgress(int) - Method in interface alluxio.grpc.CmdProgressOrBuilder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgress(GetJobProgressPRequest, StreamObserver<GetJobProgressPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
 
getJobProgress(GetJobProgressPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
 
getJobProgress(GetJobProgressPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
 
getJobProgress(GetJobProgressPRequest, StreamObserver<GetJobProgressPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
 
getJobProgress(GetJobProgressPRequest, StreamObserver<GetJobProgressPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getJobProgress(JobDescription, JobProgressReportFormat, boolean) - Method in class alluxio.master.scheduler.Scheduler
Get the job's progress report.
getJobProgressBuilder(int) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressBuilderList() - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressCount() - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressCount() - Method in class alluxio.grpc.CmdProgress
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressCount() - Method in interface alluxio.grpc.CmdProgressOrBuilder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressList() - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressList() - Method in class alluxio.grpc.CmdProgress
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressList() - Method in interface alluxio.grpc.CmdProgressOrBuilder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressOrBuilder(int) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressOrBuilder(int) - Method in class alluxio.grpc.CmdProgress
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressOrBuilder(int) - Method in interface alluxio.grpc.CmdProgressOrBuilder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressOrBuilderList() - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressOrBuilderList() - Method in class alluxio.grpc.CmdProgress
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
getJobProgressOrBuilderList() - Method in interface alluxio.grpc.CmdProgressOrBuilder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
GetJobProgressPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetJobProgressPRequest
GetJobProgressPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetJobProgressPRequest
GetJobProgressPRequestOrBuilder - Interface in alluxio.grpc
 
GetJobProgressPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetJobProgressPResponse
GetJobProgressPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetJobProgressPResponse
GetJobProgressPResponseOrBuilder - Interface in alluxio.grpc
 
getJobs() - Method in class alluxio.job.workflow.composite.CompositeConfig
 
getJobs() - Method in class alluxio.master.scheduler.JournaledJobMetaStore
 
getJobs() - Method in class alluxio.master.scheduler.Scheduler
Get jobs.
getJobs() - Method in interface alluxio.scheduler.job.JobMetaStore
 
getJobServiceSummary() - Method in interface alluxio.client.job.JobMasterClient
Gets the job service summary.
getJobServiceSummary() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getJobServiceSummary(GetJobServiceSummaryPRequest, StreamObserver<GetJobServiceSummaryPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Gets the summary of the job service.
getJobServiceSummary(GetJobServiceSummaryPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Gets the summary of the job service.
getJobServiceSummary(GetJobServiceSummaryPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Gets the summary of the job service.
getJobServiceSummary(GetJobServiceSummaryPRequest, StreamObserver<GetJobServiceSummaryPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Gets the summary of the job service.
getJobServiceSummary(GetJobServiceSummaryPRequest, StreamObserver<GetJobServiceSummaryPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
GetJobServiceSummaryPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPOptions
GetJobServiceSummaryPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPOptions
GetJobServiceSummaryPOptionsOrBuilder - Interface in alluxio.grpc
 
GetJobServiceSummaryPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPRequest
GetJobServiceSummaryPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPRequest
GetJobServiceSummaryPRequestOrBuilder - Interface in alluxio.grpc
 
GetJobServiceSummaryPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPResponse
GetJobServiceSummaryPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobServiceSummaryPResponse
GetJobServiceSummaryPResponseOrBuilder - Interface in alluxio.grpc
 
getJobSource() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.JobSource jobSource = 3;
getJobSource() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.JobSource jobSource = 3;
getJobSource() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.JobSource jobSource = 3;
getJobSource() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getJobSource() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
getJobSource() - Method in interface alluxio.job.CmdConfig
 
getJobSource() - Method in class alluxio.master.job.common.CmdInfo
Get job source.
getJobState() - Method in class alluxio.master.job.AbstractJob
Get load status.
getJobState(JobDescription) - Method in class alluxio.master.scheduler.Scheduler
Get the job's state.
getJobState() - Method in interface alluxio.scheduler.job.Job
 
getJobStatus(long, AlluxioConfiguration, boolean) - Static method in class alluxio.client.job.JobGrpcClientUtils
 
getJobStatus(long) - Method in interface alluxio.client.job.JobMasterClient
Gets the status of the given job id.
getJobStatus(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getJobStatus(GetJobStatusPRequest, StreamObserver<GetJobStatusPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Gets the status of the given job.
getJobStatus(GetJobStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Gets the status of the given job.
getJobStatus(GetJobStatusPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Gets the status of the given job.
getJobStatus(GetJobStatusPRequest, StreamObserver<GetJobStatusPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Gets the status of the given job.
getJobStatus() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional .alluxio.grpc.job.Status jobStatus = 2;
getJobStatus() - Method in class alluxio.grpc.JobStatusBlock
optional .alluxio.grpc.job.Status jobStatus = 2;
getJobStatus() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional .alluxio.grpc.job.Status jobStatus = 2;
getJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional .alluxio.grpc.job.Status job_status = 5;
getJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo
optional .alluxio.grpc.job.Status job_status = 5;
getJobStatus() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional .alluxio.grpc.job.Status job_status = 5;
getJobStatus(GetJobStatusPRequest, StreamObserver<GetJobStatusPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
getJobStatusBlock(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlock(int) - Method in class alluxio.grpc.CmdStatusBlock
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlock(int) - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlock() - Method in class alluxio.job.wire.CmdStatusBlock
Get a list of job status block for a command.
getJobStatusBlockBuilder(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockBuilderList() - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockCount() - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockCount() - Method in class alluxio.grpc.CmdStatusBlock
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockCount() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockList() - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockList() - Method in class alluxio.grpc.CmdStatusBlock
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockList() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockOrBuilder(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockOrBuilder(int) - Method in class alluxio.grpc.CmdStatusBlock
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockOrBuilder(int) - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockOrBuilderList() - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockOrBuilderList() - Method in class alluxio.grpc.CmdStatusBlock
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusBlockOrBuilderList() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
getJobStatusDetailed(long) - Method in interface alluxio.client.job.JobMasterClient
Gets detailed status of the given job id.
getJobStatusDetailed(long) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getJobStatusDetailed(GetJobStatusDetailedPRequest, StreamObserver<GetJobStatusDetailedPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Gets the status of the given job.
getJobStatusDetailed(GetJobStatusDetailedPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Gets the status of the given job.
getJobStatusDetailed(GetJobStatusDetailedPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Gets the status of the given job.
getJobStatusDetailed(GetJobStatusDetailedPRequest, StreamObserver<GetJobStatusDetailedPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Gets the status of the given job.
getJobStatusDetailed(GetJobStatusDetailedPRequest, StreamObserver<GetJobStatusDetailedPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
GetJobStatusDetailedPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPOptions
GetJobStatusDetailedPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPOptions
GetJobStatusDetailedPOptionsOrBuilder - Interface in alluxio.grpc
 
GetJobStatusDetailedPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPRequest
GetJobStatusDetailedPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPRequest
GetJobStatusDetailedPRequestOrBuilder - Interface in alluxio.grpc
 
GetJobStatusDetailedPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPResponse
GetJobStatusDetailedPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusDetailedPResponse
GetJobStatusDetailedPResponseOrBuilder - Interface in alluxio.grpc
 
GetJobStatusPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusPOptions
GetJobStatusPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusPOptions
GetJobStatusPOptionsOrBuilder - Interface in alluxio.grpc
 
GetJobStatusPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusPRequest
GetJobStatusPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusPRequest
GetJobStatusPRequestOrBuilder - Interface in alluxio.grpc
 
GetJobStatusPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusPResponse
GetJobStatusPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.GetJobStatusPResponse
GetJobStatusPResponseOrBuilder - Interface in alluxio.grpc
 
getJobStopped() - Method in class alluxio.grpc.StopJobPResponse.Builder
optional bool jobStopped = 1;
getJobStopped() - Method in class alluxio.grpc.StopJobPResponse
optional bool jobStopped = 1;
getJobStopped() - Method in interface alluxio.grpc.StopJobPResponseOrBuilder
optional bool jobStopped = 1;
getJobSubmissionTime() - Method in class alluxio.master.job.common.CmdInfo
Get submission time.
getJobTaskArgs() - Method in class alluxio.job.plan.batch.BatchedJobDefinition.BatchedJobTask
 
getJobType() - Method in class alluxio.job.plan.BatchedJobConfig
 
getJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
getJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
getJobWorkerHealth() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
getJobWorkerHealthBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
getJobWorkerHealthOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
getJobWorkerHealthOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
getJobWorkerHealthOrBuilder() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
getJobWorkerHealthReport() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter
 
getJobWorkerMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry name for job worker instance.
getJournal(URI) - Method in class alluxio.underfs.AbstractUfsManager
 
getJournal(URI) - Method in interface alluxio.underfs.UfsManager
 
getJournalCheckpointTimeWarning() - Method in class alluxio.wire.MasterWebUIOverview
 
getJournalContext() - Method in class alluxio.master.file.RpcContext
 
getJournalDir() - Method in class alluxio.multi.process.MultiProcessCluster
 
getJournalDir(int) - Method in class alluxio.multi.process.MultiProcessCluster
 
getJournalDiskMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
 
getJournalDiskWarnings() - Method in class alluxio.master.meta.JournalSpaceMonitor
 
getJournalDiskWarnings() - Method in class alluxio.wire.MasterWebUIOverview
 
getJournaled() - Method in class alluxio.master.journal.JournaledGroup
 
getJournaledNextContainerId() - Method in interface alluxio.master.block.BlockMaster
Returns the internal JournaledNextContainerId.
getJournaledNextContainerId() - Method in class alluxio.master.block.DefaultBlockMaster
 
getJournalEntries(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
getJournalEntries(int) - Method in class alluxio.proto.journal.Journal.JournalEntry
This journal entry is a list of other entries.
getJournalEntries(int) - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
This journal entry is a list of other entries.
getJournalEntriesBuilder(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
getJournalEntriesBuilderList() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
getJournalEntriesCount() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
getJournalEntriesCount() - Method in class alluxio.proto.journal.Journal.JournalEntry
This journal entry is a list of other entries.
getJournalEntriesCount() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
This journal entry is a list of other entries.
getJournalEntriesList() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
getJournalEntriesList() - Method in class alluxio.proto.journal.Journal.JournalEntry
This journal entry is a list of other entries.
getJournalEntriesList() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
This journal entry is a list of other entries.
getJournalEntriesOrBuilder(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
getJournalEntriesOrBuilder(int) - Method in class alluxio.proto.journal.Journal.JournalEntry
This journal entry is a list of other entries.
getJournalEntriesOrBuilder(int) - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
This journal entry is a list of other entries.
getJournalEntriesOrBuilderList() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
getJournalEntriesOrBuilderList() - Method in class alluxio.proto.journal.Journal.JournalEntry
This journal entry is a list of other entries.
getJournalEntriesOrBuilderList() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
This journal entry is a list of other entries.
getJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 journalEntriesSinceCheckpoint = 2;
getJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions
optional int64 journalEntriesSinceCheckpoint = 2;
getJournalEntriesSinceCheckpoint() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
optional int64 journalEntriesSinceCheckpoint = 2;
getJournalEntriesSinceCheckpoint() - Method in class alluxio.master.meta.MasterInfo
 
getJournalEntriesSinceCheckpoint() - Method in class alluxio.wire.MasterInfo
 
getJournalEntriesSinceCheckpoint() - Method in class alluxio.wire.MasterWebUIMetrics
 
getJournalEntryIterator() - Method in class alluxio.master.block.DefaultBlockMaster
 
getJournalEntryIterator() - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
getJournalEntryIterator() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getJournalEntryIterator() - Method in class alluxio.master.file.meta.MountTable.State
 
getJournalEntryIterator() - Method in interface alluxio.master.journal.DelegatingJournaled
 
getJournalEntryIterator() - Method in class alluxio.master.journal.JournaledGroup
 
getJournalEntryIterator() - Method in interface alluxio.master.journal.JournalEntryIterable
 
getJournalEntryIterator() - Method in interface alluxio.master.journal.NoopJournaled
 
getJournalEntryIterator() - Method in class alluxio.master.journal.SingleEntryJournaled
 
getJournalEntryIterator() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getJournalEntryIterator() - Method in class alluxio.master.meta.DefaultMetaMaster.State
 
getJournalEntryIterator() - Method in class alluxio.master.meta.PathProperties.State
 
getJournalEntryIterator() - Method in class alluxio.master.scheduler.JournaledJobMetaStore
 
getJournalEntryIterator() - Method in class alluxio.underfs.MasterUfsManager
 
getJournalFolder() - Method in class alluxio.master.LocalAlluxioMaster
 
getJournalFormatter() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getJournalLastCheckpointTime() - Method in class alluxio.wire.MasterWebUIMetrics
 
getJournalLocation() - Static method in class alluxio.master.journal.JournalUtils
Returns a URI for the configured location for the specified journal.
getJournalMasterClientForJobMaster() - Method in class alluxio.cli.fsadmin.command.Context
 
getJournalMasterClientForMaster() - Method in class alluxio.cli.fsadmin.command.Context
 
getJournalMasterClientForMaster() - Method in class alluxio.multi.process.MultiProcessCluster
 
getJournalName() - Method in class alluxio.master.journal.AbstractJournalProgressLogger
 
getJournalName() - Method in class alluxio.master.journal.raft.RaftJournalProgressLogger
 
getJournalName() - Method in class alluxio.master.journal.ufs.UfsJournalProgressLogger
 
getJournalSequences() - Method in class alluxio.master.backup.BackupRequestMessage
 
getJournalServices() - Method in interface alluxio.master.journal.JournalSystem
 
getJournalServices() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
getJournalSinks(Master) - Method in class alluxio.master.journal.AbstractJournalSystem
 
getJournalSinks(Master) - Method in interface alluxio.master.journal.JournalSystem
 
getJournalSinks(Master) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
getJournalSpaceMonitor() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getJournalSpaceMonitor() - Method in interface alluxio.master.meta.MetaMaster
 
getJournalSystem() - Method in class alluxio.master.CoreMasterContext
 
getJournalSystem() - Method in class alluxio.master.MasterContext
 
getJournalUfsConf() - Static method in class alluxio.master.journal.ufs.UfsJournal
 
getKeepAliveClient() - Method in class alluxio.membership.DefaultServiceEntity
Get the keepalive client instance.
getKey() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
getKey() - Method in class alluxio.grpc.LocationBlockIdListEntry
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
getKey() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
getKey() - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
getKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
getKey() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string key = 1;
getKey() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string key = 1;
getKey() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getKey() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
getKey() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
 
getKey() - Method in class alluxio.proxy.s3.ListPartsResult
 
getKey() - Method in class alluxio.s3.DeleteObjectsRequest.DeleteObject
 
getKey() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
 
getKey() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
getKey() - Method in class alluxio.s3.ListBucketResult.Content
 
getKeyBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
getKeyBytes() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
getKeyBytes() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string key = 1;
getKeyBytes() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string key = 1;
getKeyCount() - Method in class alluxio.s3.ListBucketResult
 
getKeyFromPageId(PageId) - Method in class alluxio.client.file.cache.store.MemoryPageStore
 
getKeyOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
getKeyOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
getKeyOrBuilder() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
getKeys(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
getKeys(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
repeated string keys = 2;
getKeys(int) - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
repeated string keys = 2;
getKeysBytes(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
getKeysBytes(int) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
repeated string keys = 2;
getKeysBytes(int) - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
repeated string keys = 2;
getKeysCount() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
getKeysCount() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
repeated string keys = 2;
getKeysCount() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
repeated string keys = 2;
getKeysList() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
getKeysList() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
repeated string keys = 2;
getKeysList() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
repeated string keys = 2;
getLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_accessed_ms = 30;
getLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 last_accessed_ms = 30;
getLastAccessedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 last_accessed_ms = 30;
getLastAccessTimeMs() - Method in class alluxio.client.file.URIStatus
 
getLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastAccessTimeMs = 31;
getLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo
optional int64 lastAccessTimeMs = 31;
getLastAccessTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 lastAccessTimeMs = 31;
getLastAccessTimeMs() - Method in class alluxio.master.file.meta.Inode
 
getLastAccessTimeMs() - Method in interface alluxio.master.file.meta.InodeView
 
getLastAccessTimeMs() - Method in class alluxio.master.file.meta.MutableInode
 
getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_access_time_ms = 20;
getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 last_access_time_ms = 20;
getLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 last_access_time_ms = 20;
getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_access_time_ms = 29;
getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 last_access_time_ms = 29;
getLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 last_access_time_ms = 29;
getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_access_time_ms = 18;
getLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 last_access_time_ms = 18;
getLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 last_access_time_ms = 18;
getLastAccessTimeMs() - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
 
getLastAccessTimeMs() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets last access time ms.
getLastAccessTimeMs() - Method in class alluxio.wire.FileInfo
 
getLastAccessTimeMs() - Method in class alluxio.worker.dora.OpenFileHandle
Get last accessed time.
getLastAppliedCommitIndex() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getLastAppliedIndex() - Method in class alluxio.master.journal.AbstractJournalProgressLogger
 
getLastAppliedIndex() - Method in class alluxio.master.journal.raft.RaftJournalProgressLogger
 
getLastAppliedIndex() - Method in class alluxio.master.journal.ufs.UfsJournalProgressLogger
 
getLastAppliedSequenceNumber() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 lastCheckpointTime = 1;
getLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions
optional int64 lastCheckpointTime = 1;
getLastCheckpointTime() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
optional int64 lastCheckpointTime = 1;
getLastCheckpointTime() - Method in class alluxio.wire.MasterInfo
 
getLastCheckpointTimeMs() - Method in class alluxio.master.meta.MasterInfo
 
getLastClearTime() - Method in class alluxio.master.metrics.MetricsStore
 
getLastComputed() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
Returns the worker health observed time.
getLastContactSec() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int32 lastContactSec = 3;
getLastContactSec() - Method in class alluxio.grpc.WorkerInfo
optional int32 lastContactSec = 3;
getLastContactSec() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int32 lastContactSec = 3;
getLastContactSec() - Method in class alluxio.wire.WorkerInfo
 
getLastExistingInode() - Method in class alluxio.master.file.meta.LockedInodePath
 
getLastHeartbeat() - Method in class alluxio.util.webui.NodeInfo
Gets last heartbeat.
getLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 lastHeartbeatTime = 4;
getLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus
optional int64 lastHeartbeatTime = 4;
getLastHeartbeatTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional int64 lastHeartbeatTime = 4;
getLastHeartbeatTimeMs() - Method in class alluxio.master.meta.ProxyInfo
 
getLastItem() - Method in class alluxio.underfs.UfsLoadResult
 
getLastModificationTimeMs() - Method in class alluxio.client.file.URIStatus
 
getLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastModificationTimeMs = 14;
getLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo
optional int64 lastModificationTimeMs = 14;
getLastModificationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 lastModificationTimeMs = 14;
getLastModificationTimeMs() - Method in class alluxio.master.file.meta.Inode
 
getLastModificationTimeMs() - Method in interface alluxio.master.file.meta.InodeView
 
getLastModificationTimeMs() - Method in class alluxio.master.file.meta.MutableInode
 
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 last_modification_time_ms = 2;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 last_modification_time_ms = 2;
getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 last_modification_time_ms = 2;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 last_modification_time_ms = 7;
getLastModificationTimeMs() - Method in class alluxio.wire.FileInfo
 
getLastModified() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getLastModified() - Method in class alluxio.s3.CopyObjectResult
 
getLastModified() - Method in class alluxio.s3.ListBucketResult.Content
 
getLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_modified_ms = 25;
getLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 last_modified_ms = 25;
getLastModifiedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 last_modified_ms = 25;
getLastModifiedTime() - Method in class alluxio.underfs.UfsStatus
Gets the UTC time of when the indicated path was modified recently in ms, or null if the last modified time is not available.
getLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus.Builder
optional int64 last_modified_time_ms = 3;
getLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus
optional int64 last_modified_time_ms = 3;
getLastModifiedTimeMs() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional int64 last_modified_time_ms = 3;
getLastModifiedTimeMs() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the last modified epoch time in ms.
getLastPrimaryStartSequenceNumber() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getLastSN(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalReader
Iterates over the journal files searching for the greatest SN of all the files.
getLastStatusChangeMs() - Method in class alluxio.job.plan.meta.PlanInfo
 
getLastSyncTime() - Method in class alluxio.master.file.meta.SyncCheck
 
getLastSyncTime() - Method in class alluxio.master.file.meta.SyncCheck.SyncResult
 
getLastUpdated() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 lastUpdated = 6;
getLastUpdated() - Method in class alluxio.grpc.JobInfo
optional int64 lastUpdated = 6;
getLastUpdated() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional int64 lastUpdated = 6;
getLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 lastUpdated = 3;
getLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth
optional int64 lastUpdated = 3;
getLastUpdated() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int64 lastUpdated = 3;
getLastUpdated() - Method in interface alluxio.job.wire.JobInfo
 
getLastUpdated() - Method in class alluxio.job.wire.PlanInfo
 
getLastUpdated() - Method in class alluxio.job.wire.TaskInfo
 
getLastUpdated() - Method in class alluxio.job.wire.WorkflowInfo
 
getLastUpdated() - Method in class alluxio.job.workflow.WorkflowExecution
 
getLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo.Builder
optional int64 lastUpdatedTime = 5;
getLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo
optional int64 lastUpdatedTime = 5;
getLastUpdatedTime() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional int64 lastUpdatedTime = 5;
getLastUpdatedTime() - Method in class alluxio.util.webui.UIMasterInfo
Get master last update time.
getLastUpdatedTime() - Method in class alluxio.wire.MasterInfo
 
getLastUpdatedTimeMs() - Method in class alluxio.job.MasterWorkerInfo
 
getLastUpdatedTimeMs() - Method in class alluxio.master.block.meta.MasterWorkerInfo
No locking required.
getLastUpdatedTimeMs() - Method in class alluxio.master.meta.JobMasterInfo
 
getLastUpdatedTimeMs() - Method in class alluxio.master.meta.MasterInfo
 
getLastUpdateMs() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 lastUpdateMs = 4;
getLastUpdateMs() - Method in class alluxio.grpc.JobProgress
optional int64 lastUpdateMs = 4;
getLastUpdateMs() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 lastUpdateMs = 4;
getLastUpdateTime() - Method in class alluxio.conf.AlluxioProperties
 
getLastUpdateTime() - Static method in class alluxio.conf.Configuration
 
getLastUpdateTime() - Method in class alluxio.conf.Hash
 
getLastUpdateTime() - Method in class alluxio.conf.InstancedConfiguration
 
getLastUpdateTime() - Method in class alluxio.master.meta.PathProperties
 
getLastUpdateTime() - Method in class alluxio.master.meta.PathPropertiesView
 
getLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated. 
getLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated. 
getLatest() - Method in interface alluxio.grpc.GetSnapshotInfoResponseOrBuilder
Deprecated. 
getLatestBuilder() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
getLatestCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getLatestContent() - Method in class alluxio.worker.s3.S3NettyHandler
get HTTP content of this request.
getLatestOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
getLatestOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
getLatestOrBuilder() - Method in interface alluxio.grpc.GetSnapshotInfoResponseOrBuilder
Deprecated.
getLatestSequenceNumber() - Method in interface alluxio.master.journalv0.JournalInputStream
 
getLatestSnapshot() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getLatestSnapshot() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
getLatestVersion(String, List<String>, long, long, long) - Static method in class alluxio.check.UpdateCheck
 
getLayout() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
getLayout() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.Layout layout = 6;
getLayout() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.Layout layout = 6;
getLayout() - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
getLayout() - Method in class alluxio.grpc.table.Transformation
optional .alluxio.grpc.table.Layout layout = 1;
getLayout() - Method in interface alluxio.grpc.table.TransformationOrBuilder
optional .alluxio.grpc.table.Layout layout = 1;
getLayoutBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
getLayoutBuilder() - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
getLayoutData() - Method in class alluxio.grpc.table.Layout.Builder
optional bytes layout_data = 3;
getLayoutData() - Method in class alluxio.grpc.table.Layout
optional bytes layout_data = 3;
getLayoutData() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional bytes layout_data = 3;
getLayoutOrBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
getLayoutOrBuilder() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.Layout layout = 6;
getLayoutOrBuilder() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.Layout layout = 6;
getLayoutOrBuilder() - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
getLayoutOrBuilder() - Method in class alluxio.grpc.table.Transformation
optional .alluxio.grpc.table.Layout layout = 1;
getLayoutOrBuilder() - Method in interface alluxio.grpc.table.TransformationOrBuilder
optional .alluxio.grpc.table.Layout layout = 1;
getLayoutSpec() - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
getLayoutSpec() - Method in class alluxio.grpc.table.Layout
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
getLayoutSpec() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
getLayoutSpecBuilder() - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
getLayoutSpecOrBuilder() - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
getLayoutSpecOrBuilder() - Method in class alluxio.grpc.table.Layout
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
getLayoutSpecOrBuilder() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
getLayoutType() - Method in class alluxio.grpc.table.Layout.Builder
optional string layout_type = 1;
getLayoutType() - Method in class alluxio.grpc.table.Layout
optional string layout_type = 1;
getLayoutType() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional string layout_type = 1;
getLayoutTypeBytes() - Method in class alluxio.grpc.table.Layout.Builder
optional string layout_type = 1;
getLayoutTypeBytes() - Method in class alluxio.grpc.table.Layout
optional string layout_type = 1;
getLayoutTypeBytes() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional string layout_type = 1;
getLeaderId() - Method in class alluxio.master.journal.raft.RaftJournalSystem
Get the leader id.
getLeaderId() - Method in class alluxio.wire.MasterWebUIOverview
Gets leader id.
getLeaderIndex() - Method in class alluxio.master.journal.raft.RaftJournalSystem
Gets leader index.
getLeaderIndex() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
getLeaderIndex() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo.Builder
optional string leaderMasterAddress = 1;
getLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo
optional string leaderMasterAddress = 1;
getLeaderMasterAddress() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string leaderMasterAddress = 1;
getLeaderMasterAddressBytes() - Method in class alluxio.grpc.MasterInfo.Builder
optional string leaderMasterAddress = 1;
getLeaderMasterAddressBytes() - Method in class alluxio.grpc.MasterInfo
optional string leaderMasterAddress = 1;
getLeaderMasterAddressBytes() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string leaderMasterAddress = 1;
getLeaderPath() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
getLeadingPath(int) - Method in class alluxio.AlluxioURI
Gets the first n components of the AlluxioURI path.
getLease() - Method in class alluxio.membership.DefaultServiceEntity
 
getLeaseTimeoutInSec() - Method in class alluxio.membership.DefaultServiceEntity
Get the timeout for lease in seconds.
getLeaseTTLInSec() - Method in class alluxio.membership.DefaultServiceEntity
Get the TTL for lease in seconds.
getLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 leastSignificantBits = 2;
getLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId
optional int64 leastSignificantBits = 2;
getLeastSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
optional int64 leastSignificantBits = 2;
getLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 leastSignificantBits = 2;
getLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
optional int64 leastSignificantBits = 2;
getLeastSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
optional int64 leastSignificantBits = 2;
getLength() - Method in class alluxio.client.file.URIStatus
 
getLength() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 length = 5;
getLength() - Method in class alluxio.grpc.AsyncCacheRequest
optional int64 length = 5;
getLength() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional int64 length = 5;
getLength() - Method in class alluxio.grpc.Block.Builder
The block length.
getLength() - Method in class alluxio.grpc.Block
The block length.
getLength() - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 length = 2;
getLength() - Method in class alluxio.grpc.BlockInfo
optional int64 length = 2;
getLength() - Method in interface alluxio.grpc.BlockInfoOrBuilder
optional int64 length = 2;
getLength() - Method in interface alluxio.grpc.BlockOrBuilder
The block length.
getLength() - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 length = 5;
getLength() - Method in class alluxio.grpc.CacheRequest
optional int64 length = 5;
getLength() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional int64 length = 5;
getLength() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the length of the block being committed
getLength() - Method in class alluxio.grpc.CommitBlockPRequest
the length of the block being committed
getLength() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the length of the block being committed
getLength() - Method in class alluxio.grpc.File.Builder
file length
getLength() - Method in class alluxio.grpc.File
file length
getLength() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 length = 5;
getLength() - Method in class alluxio.grpc.FileInfo
optional int64 length = 5;
getLength() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 length = 5;
getLength() - Method in interface alluxio.grpc.FileOrBuilder
file length
getLength() - Method in class alluxio.grpc.ReadableDataBuffer
 
getLength() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 length = 3;
getLength() - Method in class alluxio.grpc.ReadRequest
optional int64 length = 3;
getLength() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 length = 3;
getLength() - Method in class alluxio.grpc.Route.Builder
optional int64 length = 3;
getLength() - Method in class alluxio.grpc.Route
optional int64 length = 3;
getLength() - Method in interface alluxio.grpc.RouteOrBuilder
optional int64 length = 3;
getLength() - Method in class alluxio.master.file.meta.InodeFile
 
getLength() - Method in interface alluxio.master.file.meta.InodeFileView
 
getLength() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getLength() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
getLength() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns the length of the data.
getLength() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getLength() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getLength() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
getLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
getLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 length = 5;
getLength() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 length = 5;
getLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 length = 3;
getLength() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
getLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 length = 2;
getLength() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 length = 2;
getLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 length = 3;
getLength() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
getLength() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 length = 9;
getLength() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 length = 9;
getLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
getLength() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 length = 2;
getLength() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 length = 2;
getLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 length = 3;
getLength() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 length = 3;
getLength() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
optional int64 length = 1;
getLength() - Method in class alluxio.proto.meta.Block.BlockMeta
optional int64 length = 1;
getLength() - Method in interface alluxio.proto.meta.Block.BlockMetaOrBuilder
optional int64 length = 1;
getLength() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 length = 19;
getLength() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 length = 19;
getLength() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 length = 19;
getLength(long) - Method in class alluxio.s3.S3RangeSpec
Get real length of object.
getLength() - Method in class alluxio.underfs.options.OpenOptions
 
getLength() - Method in class alluxio.wire.BlockInfo
 
getLength() - Method in class alluxio.wire.FileInfo
 
getLength() - Method in class alluxio.worker.block.io.BlockReader
Gets the length of the block in bytes.
getLength() - Method in class alluxio.worker.dora.PagedFileReader
 
getLength() - Method in class alluxio.worker.http.ResponseFileInfo
Get the length of the file.
getLevel() - Method in class alluxio.wire.LogInfo
 
getLFULogBase() - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
 
getLibfuseVersion(AlluxioConfiguration) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the libjnifuse version preference set by user.
getList() - Method in class alluxio.collections.PrefixList
Gets the list of prefixes.
getList(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as a list.
getList(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the value for the given key as a list.
getList(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getList(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getListAllMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getListingChunkLength(AlluxioConfiguration) - Method in class alluxio.underfs.ObjectUnderFileSystem
The number of items to query in a single listing chunk.
getListingChunkLengthMax() - Method in class alluxio.underfs.ObjectUnderFileSystem
Maximum number of items in a single listing chunk supported by the under store.
getListings() - Method in class alluxio.client.file.ListStatusPartialResult
 
getListPolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
getListProxyStatusMethod() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getListStatusMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getListStatusMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getListStatusPartialMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getListType() - Method in class alluxio.s3.ListBucketOptions
 
getLiveMembers() - Method in class alluxio.membership.EtcdMembershipManager
 
getLiveMembers() - Method in class alluxio.membership.MasterMembershipManager
 
getLiveMembers() - Method in interface alluxio.membership.MembershipManager
Get healthy workers.
getLiveMembers() - Method in class alluxio.membership.StaticMembershipManager
 
getLiveNodeAddresses() - Method in class alluxio.master.meta.checkconf.ConfigurationStore
 
getLiveWorkerInfos() - Method in class alluxio.master.scheduler.DefaultWorkerProvider
 
getLiveWorkerInfos() - Method in class alluxio.master.scheduler.MembershipManagerWorkerProvider
 
getLiveWorkerInfos() - Method in interface alluxio.master.scheduler.WorkerProvider
Get live workerInfo list.
getLiveWorkerNodes() - Method in class alluxio.wire.MasterWebUIOverview
Gets live worker nodes.
getLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 liveWorkerNum = 4;
getLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
optional int32 liveWorkerNum = 4;
getLiveWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int32 liveWorkerNum = 4;
getLiveWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
 
getLiveWorkers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get live workers.
getLiveWorkers() - Method in class alluxio.client.file.FileSystemContext
Gets the live worker information list.
getLoadAverage(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
repeated double loadAverage = 2;
getLoadAverage(int) - Method in class alluxio.grpc.JobWorkerHealth
repeated double loadAverage = 2;
getLoadAverage(int) - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
repeated double loadAverage = 2;
getLoadAverage() - Method in class alluxio.job.wire.JobWorkerHealth
Returns system load average for 1, 5, and 15 minutes.
getLoadAverageCount() - Method in class alluxio.grpc.JobWorkerHealth.Builder
repeated double loadAverage = 2;
getLoadAverageCount() - Method in class alluxio.grpc.JobWorkerHealth
repeated double loadAverage = 2;
getLoadAverageCount() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
repeated double loadAverage = 2;
getLoadAverageList() - Method in class alluxio.grpc.JobWorkerHealth.Builder
repeated double loadAverage = 2;
getLoadAverageList() - Method in class alluxio.grpc.JobWorkerHealth
repeated double loadAverage = 2;
getLoadAverageList() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
repeated double loadAverage = 2;
getLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
getLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
getLoadDescendantType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
getLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions.Builder
This is deprecated since 1.1.1 and will be removed in 2.0.
getLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions
This is deprecated since 1.1.1 and will be removed in 2.0.
getLoadDirectChildren() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
This is deprecated since 1.1.1 and will be removed in 2.0.
getLoadFileMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
getLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
getLoadJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
getLoadJobBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
getLoadJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
getLoadJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
getLoadJobOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
getLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions.Builder
No data will be transferred.
getLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions
No data will be transferred.
getLoadMetadataOnly() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
No data will be transferred.
getLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest.Builder
If set false, only the metadata of file will be loaded.
getLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest
If set false, only the metadata of file will be loaded.
getLoadMetadataOnly() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
If set false, only the metadata of file will be loaded.
getLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool loadMetadataOnly = 4;
getLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions
optional bool loadMetadataOnly = 4;
getLoadMetadataOnly() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool loadMetadataOnly = 4;
getLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool load_metadata_only = 9;
getLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional bool load_metadata_only = 9;
getLoadMetadataOnly() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional bool load_metadata_only = 9;
getLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
getLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
getLoadMetadataType() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
getLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
getLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
getLoadMetadataType() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
getLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
getLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
getLoadMetadataType() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
getLoadMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string load_path = 1;
getLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required string load_path = 1;
getLoadPath() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required string load_path = 1;
getLoadPathBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string load_path = 1;
getLoadPathBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required string load_path = 1;
getLoadPathBytes() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required string load_path = 1;
getLoadState() - Static method in class alluxio.jnifuse.utils.NativeLibraryLoader
 
getLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
getLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
getLoadType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
getLocalAlluxioMaster() - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
getLocalAlluxioMaster() - Method in class alluxio.master.LocalAlluxioCluster
 
getLocalAlluxioMaster() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
getLocalAlluxioMaster() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getLocalAlluxioMasterByIndex(int) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
getLocalCacheDir() - Method in class alluxio.client.file.cache.PageInfo
 
getLocalFileMode(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's permission mode.
getLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool localFileSystem = 1;
getLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions
optional bool localFileSystem = 1;
getLocalFileSystem() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool localFileSystem = 1;
getLocalHostMetricName(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local hostname for the host this JVM is running on with '.' replaced with '_' for metrics usage.
getLocalHostName(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local host name for the host this JVM is running on.
getLocalIpAddress(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local IP address for the host this JVM is running on.
getLocalPeerId() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
getLocalPort() - Method in class alluxio.web.WebServer
Gets the actual port that the web server is listening on.
getLocation() - Method in class alluxio.grpc.table.Database.Builder
optional string location = 3;
getLocation() - Method in class alluxio.grpc.table.Database
optional string location = 3;
getLocation() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string location = 3;
getLocation() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional string location = 2;
getLocation() - Method in class alluxio.grpc.table.layout.hive.Storage
optional string location = 2;
getLocation() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional string location = 2;
getLocation() - Method in interface alluxio.master.journal.Journal
 
getLocation() - Method in class alluxio.master.journal.noop.NoopJournal
 
getLocation() - Method in class alluxio.master.journal.raft.RaftJournal
 
getLocation() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getLocation() - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
getLocation() - Method in interface alluxio.master.journalv0.Journal
 
getLocation() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getLocation() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getLocation() - Method in class alluxio.worker.block.AllocateOptions
 
getLocation() - Method in class alluxio.worker.block.io.BlockReader
 
getLocation() - Method in class alluxio.worker.dora.PagedFileReader
 
getLocationBytes() - Method in class alluxio.grpc.table.Database.Builder
optional string location = 3;
getLocationBytes() - Method in class alluxio.grpc.table.Database
optional string location = 3;
getLocationBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string location = 3;
getLocationBytes() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional string location = 2;
getLocationBytes() - Method in class alluxio.grpc.table.layout.hive.Storage
optional string location = 2;
getLocationBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional string location = 2;
getLocationInternal(UfsFileWriteRequestContext) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
getLocations(int) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocations(int) - Method in class alluxio.grpc.BlockInfo
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocations(int) - Method in interface alluxio.grpc.BlockInfoOrBuilder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocations(long) - Method in interface alluxio.master.metastore.BlockMetaStore
Gets locations for a block.
getLocations(long) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
getLocations(long) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
getLocations() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets locations.
getLocations() - Method in class alluxio.wire.BlockInfo
 
getLocations() - Method in class alluxio.wire.BlockLocationInfo
 
getLocationsBuilder(int) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsBuilderList() - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsCount() - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsCount() - Method in class alluxio.grpc.BlockInfo
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsCount() - Method in interface alluxio.grpc.BlockInfoOrBuilder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsList() - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsList() - Method in class alluxio.grpc.BlockInfo
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsList() - Method in interface alluxio.grpc.BlockInfoOrBuilder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsOrBuilder(int) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsOrBuilder(int) - Method in class alluxio.grpc.BlockInfo
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsOrBuilder(int) - Method in interface alluxio.grpc.BlockInfoOrBuilder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsOrBuilderList() - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsOrBuilderList() - Method in class alluxio.grpc.BlockInfo
repeated .alluxio.grpc.BlockLocation locations = 3;
getLocationsOrBuilderList() - Method in interface alluxio.grpc.BlockInfoOrBuilder
repeated .alluxio.grpc.BlockLocation locations = 3;
getLock() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
getLock() - Method in interface alluxio.client.file.cache.PageMetaStore
 
getLockedInodes() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
getLockedInodes() - Method in interface alluxio.master.file.meta.InodeLockList
 
getLockedInodes() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
getLockedInodeViews() - Method in interface alluxio.master.file.meta.InodeLockList
 
getLockMode() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
getLockMode() - Method in interface alluxio.master.file.meta.InodeLockList
 
getLockMode() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
getLockPattern() - Method in class alluxio.master.file.meta.LockedInodePath
 
getLockPoolSize() - Method in class alluxio.master.file.MetadataSyncLockManager
 
getLockVersion() - Method in class alluxio.master.metastore.rocks.RocksSharedLockHandle
Gets the version on the lock.
getLogDir() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getLogicalName() - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
getLogicalName() - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
getLogicalProcessorCount() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
Returns the system logical processor count.
getLogName() - Method in class alluxio.wire.LogInfo
 
getLogs() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getLong(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the long integer representation of the value for the given key.
getLong(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the long integer representation of the value for the given key.
getLong(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getLong() - Method in class alluxio.master.journal.checkpoint.LongCheckpointFormat.LongCheckpointReader
 
getLong(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getLongestRunning(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunning(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunning(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunning() - Method in class alluxio.job.wire.JobServiceSummary
 
getLongestRunningBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningCount() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningJobs() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Get the longest running jobs.
getLongestRunningList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongestRunningOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
getLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
getLongType() - Method in class alluxio.grpc.table.Value.Builder
int64 long_type = 1;
getLongType() - Method in class alluxio.grpc.table.Value
int64 long_type = 1;
getLongType() - Method in interface alluxio.grpc.table.ValueOrBuilder
int64 long_type = 1;
getLosePrimacyTime() - Method in class alluxio.wire.MasterInfo
 
getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
optional int64 losePrimacyTimeMs = 3;
getLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
optional int64 losePrimacyTimeMs = 3;
getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
getLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
optional int64 losePrimacyTimeMs = 3;
getLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional int64 losePrimacyTimeMs = 3;
getLosePrimacyTimeMs() - Method in class alluxio.master.meta.JobMasterInfo
 
getLosePrimacyTimeMs() - Method in class alluxio.master.meta.MasterInfo
 
getLostBlocksCount() - Method in interface alluxio.master.block.BlockMaster
 
getLostBlocksCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getLostBlocksIterator() - Method in interface alluxio.master.block.BlockMaster
Returns an Iterator over the lost blocks.
getLostBlocksIterator() - Method in class alluxio.master.block.DefaultBlockMaster
 
getLostFiles() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getLostFiles() - Method in interface alluxio.master.file.FileSystemMaster
 
getLostMasterInfos() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getLostMasterInfos() - Method in interface alluxio.master.meta.MetaMaster
 
getLostMasterInfos() - Method in class alluxio.wire.MasterWebUIMasters
Get info of lost masters.
getLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
Deprecated.
getLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest
Deprecated.
getLostStorage() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
Deprecated.
getLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest
Deprecated.
getLostStorage() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
Deprecated.
getLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
Deprecated.
getLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo
Deprecated.
getLostStorage() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
Deprecated.
getLostStorage() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getLostStorage() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the storage paths which were lost in the heartbeat this report represents.
getLostStorage() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getLostStorage() - Method in interface alluxio.worker.block.meta.StorageTier
 
getLostStorageCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
getLostStorageCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
getLostStorageCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of lost storage paths on all tiers
getLostStorageCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
getLostStorageCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getLostStorageCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of tier alias to a list of lost storage paths.
getLostStorageCount() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
getLostStorageCount() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getLostStorageCount() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
a map from tier alias to the lost storage paths
getLostStorageMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of lost storage paths on all tiers
getLostStorageMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of lost storage paths on all tiers
getLostStorageMap() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of lost storage paths on all tiers
getLostStorageMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of tier alias to a list of lost storage paths.
getLostStorageMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of tier alias to a list of lost storage paths.
getLostStorageMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of tier alias to a list of lost storage paths.
getLostStorageMap() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
a map from tier alias to the lost storage paths
getLostStorageMap() - Method in class alluxio.grpc.WorkerLostStorageInfo
a map from tier alias to the lost storage paths
getLostStorageMap() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
a map from tier alias to the lost storage paths
getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of lost storage paths on all tiers
getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of lost storage paths on all tiers
getLostStorageOrDefault(String, StorageList) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of lost storage paths on all tiers
getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of tier alias to a list of lost storage paths.
getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of tier alias to a list of lost storage paths.
getLostStorageOrDefault(String, StorageList) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of tier alias to a list of lost storage paths.
getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
a map from tier alias to the lost storage paths
getLostStorageOrDefault(String, StorageList) - Method in class alluxio.grpc.WorkerLostStorageInfo
a map from tier alias to the lost storage paths
getLostStorageOrDefault(String, StorageList) - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
a map from tier alias to the lost storage paths
getLostStorageOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of lost storage paths on all tiers
getLostStorageOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of lost storage paths on all tiers
getLostStorageOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of lost storage paths on all tiers
getLostStorageOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of tier alias to a list of lost storage paths.
getLostStorageOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of tier alias to a list of lost storage paths.
getLostStorageOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of tier alias to a list of lost storage paths.
getLostStorageOrThrow(String) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
a map from tier alias to the lost storage paths
getLostStorageOrThrow(String) - Method in class alluxio.grpc.WorkerLostStorageInfo
a map from tier alias to the lost storage paths
getLostStorageOrThrow(String) - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
a map from tier alias to the lost storage paths
getLostWorkerCount() - Method in interface alluxio.master.block.BlockMaster
 
getLostWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getLostWorkerInfoList() - Method in interface alluxio.client.block.BlockMasterClient
Gets the worker information of lost workers.
getLostWorkerInfoList() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getLostWorkerList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns a list of workers information.
getLostWorkerList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns a list of workers information.
getLostWorkerList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns a list of workers information.
getLostWorkerList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns a list of workers information.
getLostWorkerList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getLostWorkerList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getLostWorkerList() - Method in interface alluxio.master.file.FileSystemMaster
 
getLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 lostWorkerNum = 5;
getLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
optional int32 lostWorkerNum = 5;
getLostWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int32 lostWorkerNum = 5;
getLostWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
 
getLostWorkers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get lost workers.
getLostWorkers() - Method in class alluxio.client.file.FileSystemContext
Gets the lost worker information list.
getLostWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
 
getLostWorkersInfoList() - Method in interface alluxio.master.block.BlockMaster
 
getLostWorkersInfoList() - Method in class alluxio.master.block.DefaultBlockMaster
 
getLow() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
getLow() - Method in class alluxio.grpc.table.Range
optional .alluxio.grpc.table.Value low = 1;
getLow() - Method in interface alluxio.grpc.table.RangeOrBuilder
optional .alluxio.grpc.table.Value low = 1;
getLowBuilder() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
getLowOrBuilder() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
getLowOrBuilder() - Method in class alluxio.grpc.table.Range
optional .alluxio.grpc.table.Value low = 1;
getLowOrBuilder() - Method in interface alluxio.grpc.table.RangeOrBuilder
optional .alluxio.grpc.table.Value low = 1;
getLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
getLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData
optional .alluxio.grpc.table.Date low_value = 1;
getLowValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Date low_value = 1;
getLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
getLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional .alluxio.grpc.table.Decimal low_value = 1;
getLowValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Decimal low_value = 1;
getLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double low_value = 1;
getLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional double low_value = 1;
getLowValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional double low_value = 1;
getLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 low_value = 1;
getLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 low_value = 1;
getLowValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 low_value = 1;
getLowValueBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
getLowValueBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
getLowValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
getLowValueOrBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData
optional .alluxio.grpc.table.Date low_value = 1;
getLowValueOrBuilder() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Date low_value = 1;
getLowValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
getLowValueOrBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional .alluxio.grpc.table.Decimal low_value = 1;
getLowValueOrBuilder() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Decimal low_value = 1;
getLowWaterMark() - Method in class alluxio.master.metastore.caching.CacheConfiguration
 
getMappingPath() - Method in class alluxio.worker.http.HttpRequestUri
Get the mapping path of the request URI.
getMarker() - Method in class alluxio.s3.ListBucketOptions
 
getMarker() - Method in class alluxio.s3.ListBucketResult
 
getMask() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
getMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional .alluxio.proto.shared.AclActions maskActions = 5;
getMaskActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional .alluxio.proto.shared.AclActions maskActions = 5;
getMaskActionsBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
getMaskActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
getMaskActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional .alluxio.proto.shared.AclActions maskActions = 5;
getMaskActionsOrBuilder() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional .alluxio.proto.shared.AclActions maskActions = 5;
getMaster() - Method in class alluxio.master.LocalAlluxioJobCluster
 
getMaster(Class<T>) - Method in class alluxio.master.MasterProcess
 
getMasterAddress() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get master address.
getMasterAddress() - Method in class alluxio.client.file.FileSystemContext
 
getMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddress() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddress() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddress() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
getMasterAddress() - Method in class alluxio.grpc.JobMasterStatus
optional .alluxio.grpc.NetAddress masterAddress = 2;
getMasterAddress() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 2;
getMasterAddress() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getMasterAddress() - Method in interface alluxio.master.meta.MetaMaster
 
getMasterAddress() - Method in class alluxio.worker.block.BlockMasterClientPool
 
getMasterAddressBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
getMasterAddresses() - Method in class alluxio.client.block.AllMastersWorkerInfo
 
getMasterAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddresses(int) - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddresses(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddresses() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getMasterAddresses() - Method in interface alluxio.master.meta.MetaMaster
 
getMasterAddresses() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
getMasterAddresses() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getMasterAddresses() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMasterAddresses() - Method in class alluxio.uri.MultiMasterAuthority
 
getMasterAddressesBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesCount() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesCount() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesList() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesOrBuilder(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressesOrBuilderList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressOrBuilder() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressOrBuilder() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 1;
getMasterAddressOrBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
getMasterAddressOrBuilder() - Method in class alluxio.grpc.JobMasterStatus
optional .alluxio.grpc.NetAddress masterAddress = 2;
getMasterAddressOrBuilder() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 2;
getMasterCapacityFreePercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master capacity free percentage.
getMasterCapacityUsedPercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master capacity used percentage.
getMasterClientContext() - Method in class alluxio.client.file.FileSystemContext
 
getMasterContext() - Method in class alluxio.master.AbstractMaster
 
getMasterContext() - Method in interface alluxio.master.Master
 
getMasterContext() - Method in class alluxio.master.NoopMaster
 
getMasterContext() - Method in class alluxio.worker.block.BlockMasterClientPool
 
getMasterEmbeddedJournalAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
getMasterForEntry(Journal.JournalEntry) - Static method in class alluxio.master.journal.JournalEntryAssociation
 
getMasterHeartbeatMethod() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
 
getMasterHeartbeatMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
getMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse.Builder
The hostname of the master that did the checkpoint
getMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse
The hostname of the master that did the checkpoint
getMasterHostname() - Method in interface alluxio.grpc.CheckpointPResponseOrBuilder
The hostname of the master that did the checkpoint
getMasterHostname() - Method in class alluxio.wire.WorkerWebUIInit
Gets master ip.
getMasterHostnameBytes() - Method in class alluxio.grpc.CheckpointPResponse.Builder
The hostname of the master that did the checkpoint
getMasterHostnameBytes() - Method in class alluxio.grpc.CheckpointPResponse
The hostname of the master that did the checkpoint
getMasterHostnameBytes() - Method in interface alluxio.grpc.CheckpointPResponseOrBuilder
The hostname of the master that did the checkpoint
getMasterHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets list of masters in conf directory.
getMasterHostNotConfiguredMessage(String) - Static method in class alluxio.util.ConfigurationUtils
Returns a unified message for cases when the master hostname cannot be determined.
getMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
optional int64 masterId = 1;
getMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse
optional int64 masterId = 1;
getMasterId() - Method in interface alluxio.grpc.GetJobMasterIdPResponseOrBuilder
optional int64 masterId = 1;
getMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
optional int64 masterId = 1;
getMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse
optional int64 masterId = 1;
getMasterId() - Method in interface alluxio.grpc.GetMasterIdPResponseOrBuilder
optional int64 masterId = 1;
getMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
getMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
optional int64 masterId = 1;
getMasterId() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
optional int64 masterId = 1;
getMasterId(GetJobMasterIdPRequest, StreamObserver<GetJobMasterIdPResponse>) - Method in interface alluxio.grpc.JobMasterMasterServiceGrpc.AsyncService
Returns a master id for the given master address.
getMasterId(GetJobMasterIdPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceBlockingStub
Returns a master id for the given master address.
getMasterId(GetJobMasterIdPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceFutureStub
Returns a master id for the given master address.
getMasterId(GetJobMasterIdPRequest, StreamObserver<GetJobMasterIdPResponse>) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceStub
Returns a master id for the given master address.
getMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
getMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest
optional int64 masterId = 1;
getMasterId() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
optional int64 masterId = 1;
getMasterId(GetMasterIdPRequest, StreamObserver<GetMasterIdPResponse>) - Method in interface alluxio.grpc.MetaMasterMasterServiceGrpc.AsyncService
Returns a master id for the given master address.
getMasterId(GetMasterIdPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceBlockingStub
Returns a master id for the given master address.
getMasterId(GetMasterIdPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceFutureStub
Returns a master id for the given master address.
getMasterId(GetMasterIdPRequest, StreamObserver<GetMasterIdPResponse>) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub
Returns a master id for the given master address.
getMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional int64 masterId = 1;
getMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest
optional int64 masterId = 1;
getMasterId() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
optional int64 masterId = 1;
getMasterId(Address) - Method in class alluxio.master.job.JobMaster
Allocates an ID for the job master from the target address.
getMasterId(Address) - Method in class alluxio.master.meta.DefaultMetaMaster
 
getMasterId(GetJobMasterIdPRequest, StreamObserver<GetJobMasterIdPResponse>) - Method in class alluxio.master.meta.JobMasterMasterServiceHandler
 
getMasterId(Address) - Method in interface alluxio.master.meta.MetaMaster
Returns a master id for the given master, creating one if the master is new.
getMasterId(GetMasterIdPRequest, StreamObserver<GetMasterIdPResponse>) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
 
GetMasterIdPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterIdPOptions
GetMasterIdPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterIdPOptions
GetMasterIdPOptionsOrBuilder - Interface in alluxio.grpc
 
GetMasterIdPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterIdPRequest
GetMasterIdPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterIdPRequest
GetMasterIdPRequestOrBuilder - Interface in alluxio.grpc
 
GetMasterIdPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterIdPResponse
GetMasterIdPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterIdPResponse
GetMasterIdPResponseOrBuilder - Interface in alluxio.grpc
 
getMasterInfo(Set<MasterInfoField>) - Method in interface alluxio.client.meta.MetaMasterClient
 
getMasterInfo(Set<MasterInfoField>) - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
getMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
getMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
getMasterInfo() - Method in interface alluxio.grpc.GetMasterInfoPResponseOrBuilder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
getMasterInfo(GetMasterInfoPOptions, StreamObserver<GetMasterInfoPResponse>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
Returns information about the master.
getMasterInfo(GetMasterInfoPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
Returns information about the master.
getMasterInfo(GetMasterInfoPOptions) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
Returns information about the master.
getMasterInfo(GetMasterInfoPOptions, StreamObserver<GetMasterInfoPResponse>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
Returns information about the master.
getMasterInfo(GetMasterInfoPOptions, StreamObserver<GetMasterInfoPResponse>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
getMasterInfoBuilder() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
getMasterInfoOrBuilder() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
getMasterInfoOrBuilder() - Method in class alluxio.grpc.GetMasterInfoPResponse
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
getMasterInfoOrBuilder() - Method in interface alluxio.grpc.GetMasterInfoPResponseOrBuilder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
GetMasterInfoPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterInfoPOptions
GetMasterInfoPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterInfoPOptions
GetMasterInfoPOptionsOrBuilder - Interface in alluxio.grpc
 
GetMasterInfoPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterInfoPResponse
GetMasterInfoPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.GetMasterInfoPResponse
GetMasterInfoPResponseOrBuilder - Interface in alluxio.grpc
 
getMasterInquireClient() - Method in class alluxio.master.MasterClientContext
 
getMasterInquireClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMasterMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry names for master instance.
getMasterMetrics(Set<String>) - Static method in class alluxio.metrics.MetricsSystem
Gets all the master metrics belongs to the given metric names.
getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIBrowse
Gets master node address.
getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIData
Gets master node address.
getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIOverview
Gets master node address.
getMasterPort() - Method in class alluxio.wire.WorkerWebUIInit
Gets master port.
getMasterProcess() - Method in class alluxio.master.LocalAlluxioMaster
 
getMasterRole() - Method in class alluxio.wire.MasterWebUIOverview
Gets master role name.
getMasterRpcAddresses() - Method in interface alluxio.master.MasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.PollingMasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.SingleMasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.ZkMasterInquireClient
 
getMasterRpcAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets the RPC addresses of all masters based on the configuration.
getMasterRpcPort() - Method in class alluxio.master.LocalAlluxioCluster
 
getMasterServiceHandler() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getMasterServiceHandler() - Method in interface alluxio.master.metrics.MetricsMaster
 
getMasterServiceLoader() - Static method in class alluxio.master.ServiceUtils
 
getMasterServiceNames() - Static method in class alluxio.master.ServiceUtils
 
getMasterStatus() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Get master status.
getMasterUnderfsCapacityFreePercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master underfs capacity free percentage.
getMasterUnderfsCapacityUsedPercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master underfs capacity used percentage.
getMasterURI() - Method in class alluxio.master.LocalAlluxioCluster
 
getMasterVersions() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get master versions.
getMasterVersions(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersions(int) - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersions(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsCount() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsCount() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsList() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsOrBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsOrBuilder(int) - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsOrBuilder(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsOrBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsOrBuilderList() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMasterVersionsOrBuilderList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
getMaxCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 max_col_len = 1;
getMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional int64 max_col_len = 1;
getMaxColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional int64 max_col_len = 1;
getMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 max_col_len = 1;
getMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
optional int64 max_col_len = 1;
getMaxColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional int64 max_col_len = 1;
getMaxEvictionRetries() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
getMaxKeys() - Method in class alluxio.s3.ListBucketOptions
 
getMaxKeys() - Method in class alluxio.s3.ListBucketResult
 
getMaxSequenceNumber() - Static method in class alluxio.master.block.BlockId
 
getMaxSize() - Method in class alluxio.master.metastore.caching.CacheConfiguration
 
getMaxTimeNs() - Method in class alluxio.stress.cli.Benchmark.MethodStatistics
 
getMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional int32 maxUfsReadConcurrency = 2;
getMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions
optional int32 maxUfsReadConcurrency = 2;
getMaxUfsReadConcurrency() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional int32 maxUfsReadConcurrency = 2;
getMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
getMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int32 maxUfsReadConcurrency = 4;
getMaxUfsReadConcurrency() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int32 maxUfsReadConcurrency = 4;
getMechanismName() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
getMechanismNames(Map<String, ?>) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
 
getMedium() - Method in class alluxio.worker.block.CreateBlockOptions
 
getMediumType() - Method in class alluxio.client.file.options.OutStreamOptions
 
getMediumType() - Method in class alluxio.grpc.BlockLocation.Builder
optional string mediumType = 4;
getMediumType() - Method in class alluxio.grpc.BlockLocation
optional string mediumType = 4;
getMediumType() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional string mediumType = 4;
getMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string mediumType = 2;
getMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto
optional string mediumType = 2;
getMediumType() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
optional string mediumType = 2;
getMediumType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional string mediumType = 7;
getMediumType() - Method in class alluxio.grpc.CommitBlockPRequest
optional string mediumType = 7;
getMediumType() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
optional string mediumType = 7;
getMediumType(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
getMediumType(int) - Method in class alluxio.grpc.FileInfo
repeated string mediumType = 33;
getMediumType(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated string mediumType = 33;
getMediumType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional string medium_type = 2;
getMediumType() - Method in class alluxio.grpc.MoveBlockRequest
optional string medium_type = 2;
getMediumType() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
optional string medium_type = 2;
getMediumType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional string medium_type = 8;
getMediumType() - Method in class alluxio.grpc.WriteRequestCommand
optional string medium_type = 8;
getMediumType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional string medium_type = 8;
getMediumType() - Method in class alluxio.job.plan.replicate.MoveConfig
 
getMediumType(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
getMediumType(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
repeated string medium_type = 18;
getMediumType(int) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
repeated string medium_type = 18;
getMediumType(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
getMediumType(int) - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated string medium_type = 26;
getMediumType(int) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated string medium_type = 26;
getMediumType(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
getMediumType(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
repeated string medium_type = 16;
getMediumType(int) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
repeated string medium_type = 16;
getMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string mediumType = 3;
getMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation
optional string mediumType = 3;
getMediumType() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional string mediumType = 3;
getMediumType(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
getMediumType(int) - Method in class alluxio.proto.meta.InodeMeta.Inode
repeated string medium_type = 27;
getMediumType(int) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
repeated string medium_type = 27;
getMediumType() - Method in class alluxio.wire.BlockLocation
 
getMediumTypeBytes() - Method in class alluxio.grpc.BlockLocation.Builder
optional string mediumType = 4;
getMediumTypeBytes() - Method in class alluxio.grpc.BlockLocation
optional string mediumType = 4;
getMediumTypeBytes() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional string mediumType = 4;
getMediumTypeBytes() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string mediumType = 2;
getMediumTypeBytes() - Method in class alluxio.grpc.BlockStoreLocationProto
optional string mediumType = 2;
getMediumTypeBytes() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
optional string mediumType = 2;
getMediumTypeBytes() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional string mediumType = 7;
getMediumTypeBytes() - Method in class alluxio.grpc.CommitBlockPRequest
optional string mediumType = 7;
getMediumTypeBytes() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
optional string mediumType = 7;
getMediumTypeBytes(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
getMediumTypeBytes(int) - Method in class alluxio.grpc.FileInfo
repeated string mediumType = 33;
getMediumTypeBytes(int) - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated string mediumType = 33;
getMediumTypeBytes() - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional string medium_type = 2;
getMediumTypeBytes() - Method in class alluxio.grpc.MoveBlockRequest
optional string medium_type = 2;
getMediumTypeBytes() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
optional string medium_type = 2;
getMediumTypeBytes() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional string medium_type = 8;
getMediumTypeBytes() - Method in class alluxio.grpc.WriteRequestCommand
optional string medium_type = 8;
getMediumTypeBytes() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional string medium_type = 8;
getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
repeated string medium_type = 18;
getMediumTypeBytes(int) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
repeated string medium_type = 18;
getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated string medium_type = 26;
getMediumTypeBytes(int) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated string medium_type = 26;
getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
getMediumTypeBytes(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
repeated string medium_type = 16;
getMediumTypeBytes(int) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
repeated string medium_type = 16;
getMediumTypeBytes() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string mediumType = 3;
getMediumTypeBytes() - Method in class alluxio.proto.meta.Block.BlockLocation
optional string mediumType = 3;
getMediumTypeBytes() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional string mediumType = 3;
getMediumTypeBytes(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
getMediumTypeBytes(int) - Method in class alluxio.proto.meta.InodeMeta.Inode
repeated string medium_type = 27;
getMediumTypeBytes(int) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
repeated string medium_type = 27;
getMediumTypeCount() - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
getMediumTypeCount() - Method in class alluxio.grpc.FileInfo
repeated string mediumType = 33;
getMediumTypeCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated string mediumType = 33;
getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
repeated string medium_type = 18;
getMediumTypeCount() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
repeated string medium_type = 18;
getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
getMediumTypeCount() - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated string medium_type = 26;
getMediumTypeCount() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated string medium_type = 26;
getMediumTypeCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
getMediumTypeCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
repeated string medium_type = 16;
getMediumTypeCount() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
repeated string medium_type = 16;
getMediumTypeCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
getMediumTypeCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
repeated string medium_type = 27;
getMediumTypeCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
repeated string medium_type = 27;
getMediumTypeList() - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
getMediumTypeList() - Method in class alluxio.grpc.FileInfo
repeated string mediumType = 33;
getMediumTypeList() - Method in interface alluxio.grpc.FileInfoOrBuilder
repeated string mediumType = 33;
getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
repeated string medium_type = 18;
getMediumTypeList() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
repeated string medium_type = 18;
getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
getMediumTypeList() - Method in class alluxio.proto.journal.File.InodeFileEntry
repeated string medium_type = 26;
getMediumTypeList() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
repeated string medium_type = 26;
getMediumTypeList() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
getMediumTypeList() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
repeated string medium_type = 16;
getMediumTypeList() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
repeated string medium_type = 16;
getMediumTypeList() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
getMediumTypeList() - Method in class alluxio.proto.meta.InodeMeta.Inode
repeated string medium_type = 27;
getMediumTypeList() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
repeated string medium_type = 27;
getMediumTypes() - Method in class alluxio.master.file.meta.Inode
 
getMediumTypes() - Method in interface alluxio.master.file.meta.InodeView
 
getMediumTypes() - Method in class alluxio.master.file.meta.MutableInode
 
getMediumTypes() - Method in class alluxio.wire.FileInfo
 
getMemoryPoolNames() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getMergedJournalEntries() - Method in class alluxio.master.file.FileSystemJournalEntryMerger
 
getMergedJournalEntries() - Method in interface alluxio.master.journal.JournalEntryMerger
Returns a list of journal entries which have been merged.
getMerger() - Method in class alluxio.master.journal.MetadataSyncMergeJournalContext
 
getMessage() - Method in enum alluxio.cli.fsadmin.command.DecommissionWorkerCommand.ReturnCode
Gets the message.
getMessage(String) - Static method in class alluxio.conf.RemovedKey
gets the message pertaining to a removed key or template.
getMessage() - Method in exception alluxio.exception.AggregateException
 
getMessage(Object...) - Method in enum alluxio.exception.ExceptionMessage
Formats the message of the exception.
getMessage() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
getMessage() - Method in class alluxio.grpc.BlockStatus.Builder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.BlockStatus
A developer-facing error message
getMessage() - Method in interface alluxio.grpc.BlockStatusOrBuilder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.DataMessage
 
getMessage() - Method in class alluxio.grpc.FileFailure.Builder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.FileFailure
A developer-facing error message
getMessage() - Method in interface alluxio.grpc.FileFailureOrBuilder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.LoadFileFailure.Builder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.LoadFileFailure
A developer-facing error message
getMessage() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.RouteFailure.Builder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.RouteFailure
A developer-facing error message
getMessage() - Method in interface alluxio.grpc.RouteFailureOrBuilder
A developer-facing error message
getMessage() - Method in class alluxio.grpc.SaslMessage.Builder
optional bytes message = 2;
getMessage() - Method in class alluxio.grpc.SaslMessage
optional bytes message = 2;
getMessage() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional bytes message = 2;
getMessage() - Method in class alluxio.grpc.TransportMessage.Builder
optional bytes message = 3;
getMessage() - Method in class alluxio.grpc.TransportMessage
optional bytes message = 3;
getMessage() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional bytes message = 3;
getMessage() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
getMessage() - Method in class alluxio.proto.dataserver.Protocol.Response
optional string message = 2;
getMessage() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional string message = 2;
getMessage() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
getMessage() - Method in class alluxio.RestUtils.ErrorResponse
Gets message.
getMessage() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
getMessage() - Method in class alluxio.s3.S3Error
 
getMessage() - Method in class alluxio.wire.LogInfo
 
getMessageBytes() - Method in class alluxio.grpc.BlockStatus.Builder
A developer-facing error message
getMessageBytes() - Method in class alluxio.grpc.BlockStatus
A developer-facing error message
getMessageBytes() - Method in interface alluxio.grpc.BlockStatusOrBuilder
A developer-facing error message
getMessageBytes() - Method in class alluxio.grpc.FileFailure.Builder
A developer-facing error message
getMessageBytes() - Method in class alluxio.grpc.FileFailure
A developer-facing error message
getMessageBytes() - Method in interface alluxio.grpc.FileFailureOrBuilder
A developer-facing error message
getMessageBytes() - Method in class alluxio.grpc.LoadFileFailure.Builder
A developer-facing error message
getMessageBytes() - Method in class alluxio.grpc.LoadFileFailure
A developer-facing error message
getMessageBytes() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
A developer-facing error message
getMessageBytes() - Method in class alluxio.grpc.RouteFailure.Builder
A developer-facing error message
getMessageBytes() - Method in class alluxio.grpc.RouteFailure
A developer-facing error message
getMessageBytes() - Method in interface alluxio.grpc.RouteFailureOrBuilder
A developer-facing error message
getMessageBytes() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
getMessageBytes() - Method in class alluxio.proto.dataserver.Protocol.Response
optional string message = 2;
getMessageBytes() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional string message = 2;
getMessageType() - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
getMessageType() - Method in class alluxio.grpc.SaslMessage
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
getMessageType() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
getMessageWithUrl(String, Object...) - Method in enum alluxio.exception.ExceptionMessage
Formats the message of the exception with an url to consult.
getMeta() - Method in class alluxio.master.metastore.BlockMetaStore.Block
 
getMetaClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getMetadataCacheExpireTime() - Method in class alluxio.fuse.options.MountOptions
 
getMetadataCacheSize() - Method in class alluxio.client.file.MetadataCachingFileSystem
 
getMetadataCacheSize() - Method in class alluxio.fuse.options.MountOptions
 
getMetadataSyncRpcContext() - Method in class alluxio.master.file.InodeSyncStream
 
getMetaFS() - Method in class alluxio.proxy.s3.S3Handler
Get system user FileSystem object.
getMetaMasterClient() - Method in class alluxio.multi.process.Clients
 
getMetaMasterClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMeter() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getMeter() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getMethod() - Method in class alluxio.stress.cli.Benchmark.ProfileInput
 
getMetricCounter() - Method in class alluxio.client.block.BlockMasterClientPool
 
getMetricCounter() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
 
getMetricCounter() - Method in class alluxio.client.file.FileSystemMasterClientPool
 
getMetricCounter() - Method in class alluxio.network.netty.NettyChannelPool
 
getMetricCounter() - Method in class alluxio.resource.DynamicResourcePool
 
getMetricName() - Method in class alluxio.metrics.MetricKey
 
getMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Converts a simple string to a qualified metric name based on the process type.
getMetricNameWithTags(String, String...) - Static method in class alluxio.metrics.Metric
Gets the metric name with the appendix of tags.
getMetricNameWithUserTag(String, String) - Static method in class alluxio.metrics.Metric
Gets a metric name with a specific user tag.
getMetricRegistry() - Method in class alluxio.metrics.source.JvmSource
 
getMetricRegistry() - Method in interface alluxio.metrics.source.Source
Gets the instance of the MetricRegistry.
getMetrics() - Method in interface alluxio.client.metrics.MetricsMasterClient
Gets all the metrics stored in the current master from metric name to metric value.
getMetrics() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
 
getMetrics(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
getMetrics(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions
repeated .alluxio.grpc.Metric metrics = 1;
getMetrics(int) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.Metric metrics = 1;
getMetrics(int) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
getMetrics(int) - Method in class alluxio.grpc.ClientMetrics
repeated .alluxio.grpc.Metric metrics = 2;
getMetrics(int) - Method in interface alluxio.grpc.ClientMetricsOrBuilder
repeated .alluxio.grpc.Metric metrics = 2;
getMetrics() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
Deprecated.
getMetrics() - Method in class alluxio.grpc.GetMetricsPResponse
Deprecated.
getMetrics() - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
Deprecated.
getMetrics(GetMetricsPOptions, StreamObserver<GetMetricsPResponse>) - Method in interface alluxio.grpc.MetricsMasterClientServiceGrpc.AsyncService
Returns a map of metrics property names and their values from Alluxio metrics system.
getMetrics(GetMetricsPOptions) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceBlockingStub
Returns a map of metrics property names and their values from Alluxio metrics system.
getMetrics(GetMetricsPOptions) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub
Returns a map of metrics property names and their values from Alluxio metrics system.
getMetrics(GetMetricsPOptions, StreamObserver<GetMetricsPResponse>) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub
Returns a map of metrics property names and their values from Alluxio metrics system.
getMetrics() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getMetrics() - Method in interface alluxio.master.metrics.MetricsMaster
 
getMetrics(GetMetricsPOptions, StreamObserver<GetMetricsPResponse>) - Method in class alluxio.master.metrics.MetricsMasterClientServiceHandler
 
getMetrics() - Method in class alluxio.metrics.OperationSystemGaugeSet
 
getMetrics() - Method in class alluxio.wire.AlluxioMasterInfo
 
getMetrics() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getMetricsBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsBuilder(int) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsBuilderList() - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsClient() - Method in class alluxio.cli.fsadmin.command.Context
 
getMetricsCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsCount() - Method in class alluxio.grpc.BlockHeartbeatPOptions
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsCount() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsCount() - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsCount() - Method in class alluxio.grpc.ClientMetrics
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsCount() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsCount() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
getMetricsCount() - Method in class alluxio.grpc.GetMetricsPResponse
 
getMetricsCount() - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsHeartbeatMethod() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
 
getMetricsInfo() - Method in class alluxio.cli.fsadmin.report.MetricsOutput
Get metrics info.
getMetricsJson(String) - Static method in class alluxio.cli.bundler.command.CollectMetricsCommand
Probes Alluxio metrics json sink.
getMetricsList() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsList() - Method in class alluxio.grpc.BlockHeartbeatPOptions
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsList() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsList() - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsList() - Method in class alluxio.grpc.ClientMetrics
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsList() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsMap() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsMap() - Method in class alluxio.grpc.GetMetricsPResponse
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsMap() - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsMasterClient() - Method in class alluxio.multi.process.MultiProcessCluster
 
getMetricsOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsOrBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsOrBuilder(int) - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsOrBuilder(int) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsOrBuilder(int) - Method in class alluxio.grpc.ClientMetrics
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsOrBuilder(int) - Method in interface alluxio.grpc.ClientMetricsOrBuilder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsOrBuilderList() - Method in class alluxio.grpc.BlockHeartbeatPOptions
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsOrBuilderList() - Method in interface alluxio.grpc.BlockHeartbeatPOptionsOrBuilder
repeated .alluxio.grpc.Metric metrics = 1;
getMetricsOrBuilderList() - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsOrBuilderList() - Method in class alluxio.grpc.ClientMetrics
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsOrBuilderList() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
repeated .alluxio.grpc.Metric metrics = 2;
getMetricsOrDefault(String, MetricValue) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsOrDefault(String, MetricValue) - Method in class alluxio.grpc.GetMetricsPResponse
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsOrDefault(String, MetricValue) - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsOrThrow(String) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsOrThrow(String) - Method in class alluxio.grpc.GetMetricsPResponse
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
getMetricsOrThrow(String) - Method in interface alluxio.grpc.GetMetricsPResponseOrBuilder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
GetMetricsPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.GetMetricsPOptions
GetMetricsPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.GetMetricsPOptions
GetMetricsPOptionsOrBuilder - Interface in alluxio.grpc
 
GetMetricsPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.GetMetricsPResponse
GetMetricsPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.GetMetricsPResponse
GetMetricsPResponseOrBuilder - Interface in alluxio.grpc
 
getMetricType() - Method in class alluxio.grpc.Metric.Builder
required .alluxio.grpc.MetricType metricType = 5;
getMetricType() - Method in class alluxio.grpc.Metric
required .alluxio.grpc.MetricType metricType = 5;
getMetricType() - Method in interface alluxio.grpc.MetricOrBuilder
required .alluxio.grpc.MetricType metricType = 5;
getMetricType() - Method in class alluxio.grpc.MetricValue.Builder
optional .alluxio.grpc.MetricType metricType = 6;
getMetricType() - Method in class alluxio.grpc.MetricValue
optional .alluxio.grpc.MetricType metricType = 6;
getMetricType() - Method in interface alluxio.grpc.MetricValueOrBuilder
optional .alluxio.grpc.MetricType metricType = 6;
getMetricType() - Method in class alluxio.metrics.Metric
 
getMetricType() - Method in class alluxio.metrics.MetricKey
 
getMetricValue(String) - Static method in class alluxio.metrics.MetricsSystem
Gets metric with the given full metric name.
getMinCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getMode() - Method in class alluxio.client.file.options.OutStreamOptions
 
getMode() - Method in class alluxio.client.file.URIStatus
 
getMode() - Method in class alluxio.fuse.file.CreateFileStatus
 
getMode() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
getMode() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.PMode mode = 3;
getMode() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 3;
getMode() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
getMode() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.PMode mode = 3;
getMode() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 3;
getMode() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 mode = 18;
getMode() - Method in class alluxio.grpc.FileInfo
optional int32 mode = 18;
getMode() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 mode = 18;
getMode() - Method in class alluxio.grpc.PAcl.Builder
optional int32 mode = 4;
getMode() - Method in class alluxio.grpc.PAcl
optional int32 mode = 4;
getMode() - Method in interface alluxio.grpc.PAclOrBuilder
optional int32 mode = 4;
getMode() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
getMode() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.grpc.PMode mode = 5;
getMode() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 5;
getMode() - Method in class alluxio.grpc.UfsStatus.Builder
optional int32 mode = 6;
getMode() - Method in class alluxio.grpc.UfsStatus
optional int32 mode = 6;
getMode() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional int32 mode = 6;
getMode() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getMode() - Method in class alluxio.master.file.meta.Inode
 
getMode() - Method in interface alluxio.master.file.meta.InodeView
 
getMode() - Method in class alluxio.master.file.meta.MutableInode
 
getMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int32 mode = 4;
getMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int32 mode = 4;
getMode() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int32 mode = 4;
getMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int32 mode = 10;
getMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int32 mode = 10;
getMode() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int32 mode = 10;
getMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 mode = 16;
getMode() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 mode = 16;
getMode() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 mode = 16;
getMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int32 mode = 11;
getMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int32 mode = 11;
getMode() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int32 mode = 11;
getMode() - Method in class alluxio.security.authorization.AccessControlList
 
getMode() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getMode() - Method in class alluxio.underfs.options.CreateOptions
 
getMode() - Method in class alluxio.underfs.options.MkdirsOptions
 
getMode() - Method in class alluxio.underfs.UfsStatus
Gets the mode of the given path in short format, e.g 0700.
getMode() - Method in class alluxio.util.webui.UIFileInfo
Gets mode.
getMode() - Method in class alluxio.wire.FileInfo
 
getModeBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
getModeBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
getModeBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
getModeOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
getModeOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.PMode mode = 3;
getModeOrBuilder() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 3;
getModeOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
getModeOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.PMode mode = 3;
getModeOrBuilder() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 3;
getModeOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
getModeOrBuilder() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.grpc.PMode mode = 5;
getModeOrBuilder() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 5;
getModificationTime() - Method in class alluxio.util.webui.UIFileInfo
Gets modification time.
getModTimeTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting modification time.
getMostSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 mostSignificantBits = 1;
getMostSignificantBits() - Method in class alluxio.grpc.FsOpPId
optional int64 mostSignificantBits = 1;
getMostSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
optional int64 mostSignificantBits = 1;
getMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 mostSignificantBits = 1;
getMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
optional int64 mostSignificantBits = 1;
getMostSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
optional int64 mostSignificantBits = 1;
getMountedRootPath(AlluxioConfiguration, FuseOptions) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the path be mounted to local fuse mount point.
getMountId(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Reverse resolve a ufs uri and get mount id.
getMountId() - Method in class alluxio.client.file.options.OutStreamOptions
 
getMountId(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getMountId() - Method in class alluxio.client.file.URIStatus
 
getMountId() - Method in class alluxio.grpc.Block.Builder
optional int64 mountId = 5;
getMountId() - Method in class alluxio.grpc.Block
optional int64 mountId = 5;
getMountId() - Method in interface alluxio.grpc.BlockOrBuilder
optional int64 mountId = 5;
getMountId() - Method in class alluxio.grpc.File.Builder
optional int64 mountId = 4;
getMountId() - Method in class alluxio.grpc.File
optional int64 mountId = 4;
getMountId() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 mountId = 23;
getMountId() - Method in class alluxio.grpc.FileInfo
optional int64 mountId = 23;
getMountId() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 mountId = 23;
getMountId() - Method in interface alluxio.grpc.FileOrBuilder
optional int64 mountId = 4;
getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Reverse resolve a ufs path and get mount id.
getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Reverse resolve a ufs path and get mount id.
getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Reverse resolve a ufs path and get mount id.
getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Reverse resolve a ufs path and get mount id.
getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
Reverse resolve a ufs path and get mount id.
getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
Reverse resolve a ufs path and get mount id.
getMountId(GetMountIdPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
Reverse resolve a ufs path and get mount id.
getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
Reverse resolve a ufs path and get mount id.
getMountId() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
required int64 mountId = 1;
getMountId() - Method in class alluxio.grpc.GetMountIdPResponse
required int64 mountId = 1;
getMountId() - Method in interface alluxio.grpc.GetMountIdPResponseOrBuilder
required int64 mountId = 1;
getMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
the id of the ufs
getMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest
the id of the ufs
getMountId() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
the id of the ufs
getMountId() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 mountId = 8;
getMountId() - Method in class alluxio.grpc.MountPointInfo
optional int64 mountId = 8;
getMountId() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional int64 mountId = 8;
getMountId() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
getMountId() - Method in class alluxio.job.plan.persist.PersistConfig
 
getMountId(GetMountIdPRequest, StreamObserver<GetMountIdPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getMountId() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getMountId() - Method in class alluxio.master.file.meta.options.MountInfo
 
getMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int64 mount_id = 5;
getMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int64 mount_id = 5;
getMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int64 mount_id = 5;
getMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 mountId = 5;
getMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 mountId = 5;
getMountId() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 mountId = 5;
getMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 mount_id = 1;
getMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
optional int64 mount_id = 1;
getMountId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
optional int64 mount_id = 1;
getMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional int64 mount_id = 6;
getMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional int64 mount_id = 6;
getMountId() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional int64 mount_id = 6;
getMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional int64 mount_id = 2;
getMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
optional int64 mount_id = 2;
getMountId() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
optional int64 mount_id = 2;
getMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional int64 mount_id = 2;
getMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
optional int64 mount_id = 2;
getMountId() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
optional int64 mount_id = 2;
getMountId() - Method in class alluxio.wire.FileInfo
 
getMountId() - Method in class alluxio.wire.MountPointInfo
 
getMountId(String) - Method in class alluxio.worker.file.FileSystemMasterClient
Reverse resolve a ufs uri and get mount id.
getMountIdFromUfsPath(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getMountIdFromUfsPath(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Returns the mount id according to the ufs path.
GetMountIdPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountIdPRequest
GetMountIdPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountIdPRequest
GetMountIdPRequestOrBuilder - Interface in alluxio.grpc
 
GetMountIdPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountIdPResponse
GetMountIdPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountIdPResponse
GetMountIdPResponseOrBuilder - Interface in alluxio.grpc
 
getMountInfo(long) - Method in class alluxio.master.file.meta.MountTable
 
getMountInfo(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Gets mount information for the path.
getMountInfo() - Method in class alluxio.master.file.meta.MountTable.ReverseResolution
 
getMountMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getMountOptions() - Method in class alluxio.fuse.options.FuseCliOptions
 
getMountOptions() - Method in class alluxio.fuse.options.MountCliOptions
 
getMountOptions() - Method in class alluxio.wire.UfsInfo
 
getMountPath() - Method in class alluxio.wire.JournalDiskInfo
 
getMountPoint() - Method in class alluxio.fuse.options.FuseCliOptions
 
getMountPoint() - Method in class alluxio.grpc.FileInfo.Builder
optional bool mountPoint = 20;
getMountPoint() - Method in class alluxio.grpc.FileInfo
optional bool mountPoint = 20;
getMountPoint() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool mountPoint = 20;
getMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Returns the closest ancestor mount point the given path is nested under.
getMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
getMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool mount_point = 11;
getMountPoint() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool mount_point = 11;
getMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool mount_point = 2;
getMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional bool mount_point = 2;
getMountPoint() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional bool mount_point = 2;
getMountPoint() - Method in class alluxio.util.UnixMountInfo
 
getMountPoint() - Method in class alluxio.util.webui.UIMountPointInfo
Gets mount point.
getMountPointInfos() - Method in class alluxio.wire.MasterWebUIMountTable
Get mount point infos [ ].
getMountPointInfoSummary(boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getMountPointInfoSummary() - Method in interface alluxio.master.file.FileSystemMaster
This is the same as calling FileSystemMaster.getMountPointInfoSummary(boolean) with true argument.
getMountPointInfoSummary(boolean) - Method in interface alluxio.master.file.FileSystemMaster
 
getMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
Deprecated.
getMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse
Deprecated.
getMountPoints() - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
Deprecated.
getMountPoints() - Method in class alluxio.wire.AlluxioMasterInfo
 
getMountPointsCount() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
getMountPointsCount() - Method in class alluxio.grpc.GetMountTablePResponse
 
getMountPointsCount() - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsMap() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsMap() - Method in class alluxio.grpc.GetMountTablePResponse
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsMap() - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsOrDefault(String, MountPointInfo) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsOrDefault(String, MountPointInfo) - Method in class alluxio.grpc.GetMountTablePResponse
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsOrDefault(String, MountPointInfo) - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsOrThrow(String) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsOrThrow(String) - Method in class alluxio.grpc.GetMountTablePResponse
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountPointsOrThrow(String) - Method in interface alluxio.grpc.GetMountTablePResponseOrBuilder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
getMountSpecificConf() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getMountTable(boolean) - Method in class alluxio.client.file.DelegatingFileSystem
 
getMountTable() - Method in interface alluxio.client.file.FileSystem
Lists all mount points and their corresponding under storage addresses.
getMountTable(boolean) - Method in interface alluxio.client.file.FileSystem
Lists all mount points and their corresponding under storage addresses.
getMountTable(boolean) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
getMountTable() - Method in interface alluxio.client.file.FileSystemMasterClient
Lists all mount points and their corresponding under storage addresses.
getMountTable(boolean) - Method in interface alluxio.client.file.FileSystemMasterClient
Lists all mount points and their corresponding under storage addresses.
getMountTable(boolean) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getMountTable(boolean) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getMountTable(GetMountTablePRequest, StreamObserver<GetMountTablePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Returns a map from each Alluxio path to information of corresponding mount point
getMountTable(GetMountTablePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Returns a map from each Alluxio path to information of corresponding mount point
getMountTable(GetMountTablePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Returns a map from each Alluxio path to information of corresponding mount point
getMountTable(GetMountTablePRequest, StreamObserver<GetMountTablePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Returns a map from each Alluxio path to information of corresponding mount point
getMountTable() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getMountTable(GetMountTablePRequest, StreamObserver<GetMountTablePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getMountTable() - Method in class alluxio.master.file.meta.MountTable
Returns a copy of the current mount table, the mount table is a map from Alluxio file system URIs to the corresponding mount point information.
getMountTable() - Method in class alluxio.master.file.meta.MountTable.State
 
GetMountTablePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountTablePRequest
GetMountTablePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountTablePRequest
GetMountTablePRequestOrBuilder - Interface in alluxio.grpc
 
GetMountTablePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountTablePResponse
GetMountTablePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetMountTablePResponse
GetMountTablePResponseOrBuilder - Interface in alluxio.grpc
 
getMoveBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
getMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
getMoveJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
getMoveJobBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
getMoveJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
getMoveJobOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
getMoveJobOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
getMoveMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getMs(String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Converts the input time into millisecond unit.
getMs(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the time of key in millisecond unit.
getMs(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the time of key in millisecond unit.
getMs(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getMs(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getMsArg(CommandLine, Option, long) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets the value of an option from the command line.
getMsg() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
optional string msg = 1;
getMsg() - Method in class alluxio.grpc.TransferLeaderMessage
optional string msg = 1;
getMsg() - Method in interface alluxio.grpc.TransferLeaderMessageOrBuilder
optional string msg = 1;
getMsgBytes() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
optional string msg = 1;
getMsgBytes() - Method in class alluxio.grpc.TransferLeaderMessage
optional string msg = 1;
getMsgBytes() - Method in interface alluxio.grpc.TransferLeaderMessageOrBuilder
optional string msg = 1;
getMultipartMetaFilepathForUploadId(String) - Static method in class alluxio.proxy.s3.S3RestUtils
 
getMultipartTemporaryDirForObject(String, String, String) - Static method in class alluxio.proxy.s3.S3RestUtils
 
getMultipartUploadEnabled() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getMultiple(String, int) - Method in class alluxio.client.file.dora.ConsistentHashProvider
Finds multiple workers from the hash ring.
getMultipleDataFileChannel(Channel, long) - Method in class alluxio.worker.dora.PagedFileReader
Get a CompositeDataBuffer which has a list of DataFileChannel.
getMutable(long, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
getMutable(long, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
getMutable(long, ReadOption) - Method in interface alluxio.master.metastore.InodeStore
Gets a mutable representation of the specified inode.
getMutable(long) - Method in interface alluxio.master.metastore.InodeStore
 
getMutable(long, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
getMutableAddedBlocksOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
Deprecated.
getMutableCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
Deprecated.
getMutableCapacityBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
Deprecated.
getMutableCapacityBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
Deprecated.
getMutableColumn() - Method in class alluxio.grpc.table.FileStatistics.Builder
Deprecated.
getMutableColumnConstraints() - Method in class alluxio.grpc.table.Constraint.Builder
Deprecated.
getMutableCurrentBlocksOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getMutableErrors() - Method in class alluxio.grpc.ConfigCheckReport.Builder
Deprecated.
getMutableErrors() - Method in class alluxio.grpc.PolicyStatus.Builder
Deprecated.
getMutableLostStorage() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
Deprecated.
getMutableLostStorage() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getMutableLostStorage() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
Deprecated.
getMutableMetrics() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
Deprecated.
getMutableMountPoints() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
Deprecated.
getMutableOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
Deprecated.
getMutableParameter() - Method in class alluxio.grpc.table.Database.Builder
Deprecated.
getMutableParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
Deprecated.
getMutableParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
Deprecated.
getMutablePartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
Deprecated.
getMutablePathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
Deprecated.
getMutableProperties() - Method in class alluxio.grpc.MountPointInfo.Builder
Deprecated.
getMutableProperties() - Method in class alluxio.grpc.MountPOptions.Builder
Deprecated.
getMutableProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
Deprecated.
getMutableProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
Deprecated.
getMutableProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
Deprecated.
getMutableSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
Deprecated.
getMutableSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
Deprecated.
getMutableStats() - Method in class alluxio.grpc.table.Layout.Builder
Deprecated.
getMutableStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
Deprecated.
getMutableTablesErrors() - Method in class alluxio.grpc.table.SyncStatus.Builder
Deprecated.
getMutableTags() - Method in class alluxio.grpc.Metric.Builder
Deprecated.
getMutableTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
Deprecated.
getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
Deprecated.
getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getMutableUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
Deprecated.
getMutableValues() - Method in class alluxio.grpc.InconsistentProperty.Builder
Deprecated.
getMutableWarns() - Method in class alluxio.grpc.ConfigCheckReport.Builder
Deprecated.
getMutableXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
Deprecated.
getMutableXattr() - Method in class alluxio.grpc.CreateFilePOptions.Builder
Deprecated.
getMutableXattr() - Method in class alluxio.grpc.FileInfo.Builder
Deprecated.
getMutableXattr() - Method in class alluxio.grpc.SetAttributePOptions.Builder
Deprecated.
getMutableXattr() - Method in class alluxio.grpc.UfsStatus.Builder
Deprecated.
getMutableXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
Deprecated.
getMutableXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
Deprecated.
getMutableXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
Deprecated.
getMutableXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Deprecated.
getMyRunningWorker() - Method in class alluxio.scheduler.job.Task
Get the worker info this task runs on.
getName() - Method in class alluxio.AlluxioURI
Gets the final component of the AlluxioURI.
getName() - Method in class alluxio.cli.ClusterConfConsistencyValidationTask
 
getName() - Method in class alluxio.cli.hdfs.HdfsConfParityValidationTask
 
getName() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
 
getName() - Method in class alluxio.cli.hdfs.HdfsProxyUserValidationTask
 
getName() - Method in class alluxio.cli.hdfs.HdfsVersionValidationTask
 
getName() - Method in class alluxio.cli.hdfs.SecureHdfsValidationTask
 
getName() - Method in class alluxio.cli.hms.CreateHmsClientValidationTask
 
getName() - Method in class alluxio.cli.hms.DatabaseValidationTask
 
getName() - Method in class alluxio.cli.hms.TableValidationTask
 
getName() - Method in class alluxio.cli.hms.UriCheckTask
 
getName() - Method in class alluxio.cli.NativeLibValidationTask
 
getName() - Method in class alluxio.cli.PortAvailabilityValidationTask
 
getName() - Method in class alluxio.cli.RamDiskMountPrivilegeValidationTask
 
getName() - Method in class alluxio.cli.SshValidationTask
 
getName() - Method in class alluxio.cli.StorageSpaceValidationTask
 
getName() - Method in class alluxio.cli.UfsDirectoryValidationTask
 
getName() - Method in class alluxio.cli.UfsSuperUserValidationTask
 
getName() - Method in class alluxio.cli.UfsVersionValidationTask
 
getName() - Method in class alluxio.cli.UserLimitValidationTask
 
getName() - Method in interface alluxio.cli.ValidationTask
Gets the name of the task.
getName() - Method in class alluxio.cli.ValidationTaskResult
 
getName() - Method in class alluxio.client.file.URIStatus
For example for the uri: alluxio://host:1000/foo/bar/baz, baz is the name.
getName() - Method in class alluxio.conf.PropertyKey
 
getName() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string name = 1;
getName() - Method in class alluxio.grpc.ConfigProperty
optional string name = 1;
getName() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string name = 1;
getName() - Method in class alluxio.grpc.FileInfo.Builder
optional string name = 2;
getName() - Method in class alluxio.grpc.FileInfo
optional string name = 2;
getName() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string name = 2;
getName() - Method in class alluxio.grpc.InconsistentProperty.Builder
optional string name = 1;
getName() - Method in class alluxio.grpc.InconsistentProperty
optional string name = 1;
getName() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
optional string name = 1;
getName() - Method in class alluxio.grpc.JobInfo.Builder
Some jobs don't have these
getName() - Method in class alluxio.grpc.JobInfo
Some jobs don't have these
getName() - Method in interface alluxio.grpc.JobInfoOrBuilder
Some jobs don't have these
getName() - Method in class alluxio.grpc.ListAllPOptions.Builder
optional string name = 2;
getName() - Method in class alluxio.grpc.ListAllPOptions
optional string name = 2;
getName() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
optional string name = 2;
getName() - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
getName() - Method in class alluxio.grpc.Metric
optional string name = 3;
getName() - Method in interface alluxio.grpc.MetricOrBuilder
optional string name = 3;
getName() - Method in class alluxio.grpc.PolicyInfo.Builder
optional string name = 2;
getName() - Method in class alluxio.grpc.PolicyInfo
optional string name = 2;
getName() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional string name = 2;
getName() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
getName() - Method in class alluxio.grpc.table.FieldSchema
optional string name = 2;
getName() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string name = 2;
getName() - Method in class alluxio.grpc.UfsStatus.Builder
optional string name = 1;
getName() - Method in class alluxio.grpc.UfsStatus
optional string name = 1;
getName() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string name = 1;
getName() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getName() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
getName() - Method in interface alluxio.job.CmdConfig
 
getName() - Method in interface alluxio.job.JobConfig
 
getName() - Method in class alluxio.job.plan.BatchedJobConfig
 
getName() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
getName() - Method in class alluxio.job.plan.NoopPlanConfig
 
getName() - Method in class alluxio.job.plan.persist.PersistConfig
 
getName() - Method in class alluxio.job.plan.replicate.MoveConfig
 
getName() - Method in interface alluxio.job.wire.JobInfo
 
getName() - Method in class alluxio.job.wire.PlanInfo
 
getName() - Method in class alluxio.job.wire.TaskInfo
 
getName() - Method in class alluxio.job.wire.WorkflowInfo
 
getName() - Method in class alluxio.job.workflow.composite.CompositeConfig
 
getName() - Method in class alluxio.job.workflow.composite.CompositeExecution
 
getName() - Method in class alluxio.job.workflow.WorkflowExecution
 
getName() - Method in class alluxio.master.block.BlockMasterFactory
 
getName() - Method in class alluxio.master.block.DefaultBlockMaster
 
getName() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getName() - Method in class alluxio.master.file.FileSystemMasterFactory
 
getName() - Method in class alluxio.master.file.meta.Edge
 
getName() - Method in class alluxio.master.file.meta.Inode
 
getName() - Method in interface alluxio.master.file.meta.InodeView
 
getName() - Method in class alluxio.master.file.meta.MutableInode
 
getName() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
 
getName() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
 
getName() - Method in class alluxio.master.job.JobMaster
 
getName() - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader.Entry
 
getName() - Method in class alluxio.master.journal.DefaultJournalMaster
 
getName() - Method in class alluxio.master.journal.JournalMasterFactory
 
getName() - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
 
getName() - Method in interface alluxio.master.MasterFactory
 
getName() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getName() - Method in class alluxio.master.meta.MetaMasterFactory
 
getName() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getName() - Method in class alluxio.master.metrics.MetricsMasterFactory
 
getName() - Method in class alluxio.master.NoopMaster
 
getName() - Method in class alluxio.metrics.Metric
 
getName() - Method in class alluxio.metrics.MetricKey
 
getName() - Method in interface alluxio.metrics.MetricsAggregator
 
getName() - Method in class alluxio.metrics.MetricsFilter
 
getName() - Method in class alluxio.metrics.source.JvmSource
 
getName() - Method in interface alluxio.metrics.source.Source
Gets the name of the Source.
getName() - Method in class alluxio.metrics.TimeSeries
 
getName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string name = 3;
getName() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string name = 3;
getName() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string name = 3;
getName() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string name = 3;
getName() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string name = 1;
getName() - Method in class alluxio.proto.journal.Job.FileFilter
required string name = 1;
getName() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
required string name = 1;
getName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional string name = 2;
getName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional string name = 2;
getName() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional string name = 2;
getName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
optional string name = 1;
getName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
optional string name = 1;
getName() - Method in interface alluxio.proto.journal.Policy.PolicyRemoveEntryOrBuilder
optional string name = 1;
getName() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string name = 6;
getName() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string name = 6;
getName() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string name = 6;
getName() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional string name = 1;
getName() - Method in class alluxio.proto.shared.Acl.NamedAclActions
optional string name = 1;
getName() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
optional string name = 1;
getName() - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
 
getName() - Method in class alluxio.s3.ListBucketResult
 
getName() - Method in class alluxio.security.CurrentUser
 
getName() - Method in class alluxio.security.User
 
getName() - Method in interface alluxio.Server
 
getName() - Method in class alluxio.stress.job.StressBenchConfig
 
getName() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the name of the object.
getName() - Method in class alluxio.underfs.UfsStatus
 
getName() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getName() - Method in class alluxio.util.logging.SamplingLogger
 
getName() - Method in class alluxio.util.webui.UIFileInfo
Gets name.
getName() - Method in class alluxio.wire.FileInfo
 
getName() - Method in class alluxio.wire.InconsistentProperty
 
getName() - Method in class alluxio.wire.Property
 
getName() - Method in class alluxio.worker.dora.PagedDoraWorker
 
getName() - Method in class alluxio.worker.http.ResponseFileInfo
Get the name of the file.
getName() - Method in class alluxio.worker.JobWorker
 
getNameBytes() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string name = 1;
getNameBytes() - Method in class alluxio.grpc.ConfigProperty
optional string name = 1;
getNameBytes() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string name = 1;
getNameBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.FileInfo
optional string name = 2;
getNameBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.InconsistentProperty.Builder
optional string name = 1;
getNameBytes() - Method in class alluxio.grpc.InconsistentProperty
optional string name = 1;
getNameBytes() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
optional string name = 1;
getNameBytes() - Method in class alluxio.grpc.JobInfo.Builder
Some jobs don't have these
getNameBytes() - Method in class alluxio.grpc.JobInfo
Some jobs don't have these
getNameBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
Some jobs don't have these
getNameBytes() - Method in class alluxio.grpc.ListAllPOptions.Builder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.ListAllPOptions
optional string name = 2;
getNameBytes() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
getNameBytes() - Method in class alluxio.grpc.Metric
optional string name = 3;
getNameBytes() - Method in interface alluxio.grpc.MetricOrBuilder
optional string name = 3;
getNameBytes() - Method in class alluxio.grpc.PolicyInfo.Builder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.PolicyInfo
optional string name = 2;
getNameBytes() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.table.FieldSchema
optional string name = 2;
getNameBytes() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string name = 2;
getNameBytes() - Method in class alluxio.grpc.UfsStatus.Builder
optional string name = 1;
getNameBytes() - Method in class alluxio.grpc.UfsStatus
optional string name = 1;
getNameBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string name = 1;
getNameBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string name = 3;
getNameBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string name = 3;
getNameBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string name = 3;
getNameBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string name = 3;
getNameBytes() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string name = 1;
getNameBytes() - Method in class alluxio.proto.journal.Job.FileFilter
required string name = 1;
getNameBytes() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
required string name = 1;
getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional string name = 2;
getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional string name = 2;
getNameBytes() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional string name = 2;
getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
optional string name = 1;
getNameBytes() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
optional string name = 1;
getNameBytes() - Method in interface alluxio.proto.journal.Policy.PolicyRemoveEntryOrBuilder
optional string name = 1;
getNameBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string name = 6;
getNameBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string name = 6;
getNameBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string name = 6;
getNameBytes() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional string name = 1;
getNameBytes() - Method in class alluxio.proto.shared.Acl.NamedAclActions
optional string name = 1;
getNameBytes() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
optional string name = 1;
getNamedGroup(String) - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedGroupActions() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedGroupsProto(ExtendedACLEntries) - Static method in class alluxio.util.proto.ProtoUtils
 
getNamedUser(String) - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedUserActions() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedUsersProto(ExtendedACLEntries) - Static method in class alluxio.util.proto.ProtoUtils
 
getNamespace() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
 
getNamespace() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
 
getNeedsSyncMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getNegotiatedProperty(String) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
getNestedProperties(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets a set of properties that share a given common prefix key as a map.
getNestedProperties(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets a set of properties that share a given common prefix key as a map.
getNestedProperties(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getNestedProperties(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getNetAddress() - Method in class alluxio.client.block.BlockWorkerInfo
 
getNettyChannelPools() - Method in class alluxio.client.file.FileSystemContext
 
getNettyClientStateMachine() - Method in class alluxio.client.file.dora.netty.event.ResponseEventContext
Get the NettyClientStateMachine.
getNettyDataLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getNettyDataLocalPort() - Method in interface alluxio.worker.WorkerProcess
 
getNettyDataPort() - Method in class alluxio.wire.WorkerNetAddress
 
getNettyOutput() - Method in class alluxio.grpc.ReadableDataBuffer
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
getNettyOutput() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns an object for writing to a netty channel.
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
getNetworkGroup() - Method in class alluxio.grpc.GrpcChannelBuilder
 
getNetworkGroup() - Method in class alluxio.grpc.GrpcChannelKey
 
getNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
getNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
getNewBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
getNewBlockBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
getNewBlockId() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getNewBlockIdForFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
 
getNewBlockIdForFile(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getNewBlockIdForFile(GetNewBlockIdForFilePRequest, StreamObserver<GetNewBlockIdForFilePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Generates a new block id for the given file.
getNewBlockIdForFile(GetNewBlockIdForFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Generates a new block id for the given file.
getNewBlockIdForFile(GetNewBlockIdForFilePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Generates a new block id for the given file.
getNewBlockIdForFile(GetNewBlockIdForFilePRequest, StreamObserver<GetNewBlockIdForFilePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Generates a new block id for the given file.
getNewBlockIdForFile(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getNewBlockIdForFile(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Gets a new block id for the next block of a given file to write to.
getNewBlockIdForFile(GetNewBlockIdForFilePRequest, StreamObserver<GetNewBlockIdForFilePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
GetNewBlockIdForFilePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePOptions
GetNewBlockIdForFilePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePOptions
GetNewBlockIdForFilePOptionsOrBuilder - Interface in alluxio.grpc
 
GetNewBlockIdForFilePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePRequest
GetNewBlockIdForFilePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePRequest
GetNewBlockIdForFilePRequestOrBuilder - Interface in alluxio.grpc
 
GetNewBlockIdForFilePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePResponse
GetNewBlockIdForFilePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetNewBlockIdForFilePResponse
GetNewBlockIdForFilePResponseOrBuilder - Interface in alluxio.grpc
 
getNewBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
getNewBlockOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
getNewBlockOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
getNewContainerId() - Method in class alluxio.master.block.BlockContainerIdGenerator
 
getNewContainerId() - Method in interface alluxio.master.block.ContainerIdGenerable
 
getNewContainerId() - Method in class alluxio.master.block.DefaultBlockMaster
 
getNewerVersionAvailable() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getNewerVersionAvailable() - Method in interface alluxio.master.meta.MetaMaster
 
getNewerVersionAvailable() - Method in class alluxio.wire.MasterWebUIInit
Gets newer version available.
getNewJobId() - Method in class alluxio.job.meta.JobIdGenerator
 
getNewJobId() - Method in class alluxio.master.job.JobMaster
 
getNewName() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_name = 5;
getNewName() - Method in class alluxio.proto.journal.File.RenameEntry
optional string new_name = 5;
getNewName() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string new_name = 5;
getNewNameBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_name = 5;
getNewNameBytes() - Method in class alluxio.proto.journal.File.RenameEntry
optional string new_name = 5;
getNewNameBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string new_name = 5;
getNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 new_parent_id = 4;
getNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 new_parent_id = 4;
getNewParentId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 new_parent_id = 4;
getNewPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_path = 7;
getNewPath() - Method in class alluxio.proto.journal.File.RenameEntry
optional string new_path = 7;
getNewPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string new_path = 7;
getNewPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_path = 7;
getNewPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry
optional string new_path = 7;
getNewPathBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string new_path = 7;
getNextBatchBlocks(int) - Method in class alluxio.master.job.LoadJob
Get next batch of blocks.
getNextChunk() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Gets next chunk of object listings.
getNextChunk() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
 
getNextChunk() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunkV1
 
getNextContainerId() - Method in class alluxio.master.block.BlockContainerIdGenerator
 
getNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
optional int64 next_container_id = 1;
getNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
optional int64 next_container_id = 1;
getNextContainerId() - Method in interface alluxio.proto.journal.Block.BlockContainerIdGeneratorEntryOrBuilder
optional int64 next_container_id = 1;
getNextContinuationToken() - Method in class alluxio.s3.ListBucketResult
 
getNextInputStream() - Method in interface alluxio.master.journalv0.JournalReader
 
getNextInputStream() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
getNextInterval(long, long) - Method in class alluxio.heartbeat.CronExpressionIntervalSupplier
 
getNextInterval(long, long) - Method in class alluxio.heartbeat.FixedIntervalSupplier
 
getNextInterval(long, long) - Method in interface alluxio.heartbeat.SleepIntervalSupplier
Gets the next interval for sleeping.
getNextMarker() - Method in class alluxio.s3.ListBucketResult
 
getNextRoutes(int) - Method in class alluxio.master.job.CopyJob
Get next batch of blocks.
getNextRoutes(int) - Method in class alluxio.master.job.MoveJob
Get next batch of blocks.
getNextSequenceNumber() - Method in interface alluxio.master.journal.JournalReader
Gets the the sequence number of the next journal log entry to read.
getNextSequenceNumber() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
getNextSequenceNumber() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalLogWriter
 
getNextSequenceNumber() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
getNextSequenceNumber() - Method in interface alluxio.master.journalv0.JournalWriter
 
getNextSequenceNumber() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
getNextSequenceNumberToCheckpoint() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getNextSequenceNumberToWrite() - Method in class alluxio.master.journal.raft.RaftJournalWriter
 
getNextSequenceNumberToWrite() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.CopyJob
get next load task.
getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.DoraLoadJob
 
getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.LoadJob
get next load task.
getNextTasks(Collection<WorkerInfo>) - Method in class alluxio.master.job.MoveJob
get next move task.
getNextTasks(Collection<WorkerInfo>) - Method in interface alluxio.scheduler.job.Job
 
getNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set, do not try to cache the block locally when reading the data from the UFS.
getNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
If set, do not try to cache the block locally when reading the data from the UFS.
getNoCache() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
If set, do not try to cache the block locally when reading the data from the UFS.
getNodeAddress() - Method in class alluxio.common.RpcPortHealthCheckClient
 
getNodeLocalWorker() - Method in class alluxio.client.file.FileSystemContext
 
getNodeResults() - Method in class alluxio.stress.common.GeneralBenchSummary
 
getNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
optional .alluxio.grpc.journal.NodeState node_state = 1;
getNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse
optional .alluxio.grpc.journal.NodeState node_state = 1;
getNodeState() - Method in interface alluxio.grpc.GetNodeStatePResponseOrBuilder
optional .alluxio.grpc.journal.NodeState node_state = 1;
getNodeState(GetNodeStatePRequest, StreamObserver<GetNodeStatePResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
Gets the state of the current node and returns whether it is primary or standby.
getNodeState(GetNodeStatePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
Gets the state of the current node and returns whether it is primary or standby.
getNodeState(GetNodeStatePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
Gets the state of the current node and returns whether it is primary or standby.
getNodeState(GetNodeStatePRequest, StreamObserver<GetNodeStatePResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
Gets the state of the current node and returns whether it is primary or standby.
getNodeState() - Method in class alluxio.master.journal.DefaultJournalMaster
 
getNodeState() - Method in interface alluxio.master.journal.JournalMaster
Gets the node state.
getNodeState(GetNodeStatePRequest, StreamObserver<GetNodeStatePResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
 
GetNodeStatePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetNodeStatePRequest
GetNodeStatePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetNodeStatePRequest
GetNodeStatePRequestOrBuilder - Interface in alluxio.grpc
 
GetNodeStatePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetNodeStatePResponse
GetNodeStatePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetNodeStatePResponse
GetNodeStatePResponseOrBuilder - Interface in alluxio.grpc
 
getNonExistingDirectoryStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting status of non-existent directory.
getNonExistingFileStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting status of non-existent file.
getNonExistingPathStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for getting status of non-existent path.
getNormalNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
Get normal node infos node info [ ].
getNotifyWorkerIdMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getNow(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the result value (or throws any encountered exception) if completed, else returns the given valueIfAbsent.
getNTotalFile() - Method in class alluxio.wire.MasterWebUIBrowse
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.MasterWebUILogs
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.WorkerWebUILogs
Gets n total file.
getNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 numActiveTasks = 6;
getNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth
optional int32 numActiveTasks = 6;
getNumActiveTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int32 numActiveTasks = 6;
getNumActiveTasks() - Method in class alluxio.job.wire.JobWorkerHealth
 
getNumActiveTasks() - Method in class alluxio.worker.job.task.PausableThreadPoolExecutor
 
getNumActiveTasks() - Method in class alluxio.worker.job.task.TaskExecutorManager
 
getNumber() - Method in enum alluxio.grpc.BackupState
 
getNumber() - Method in enum alluxio.grpc.Bits
 
getNumber() - Method in enum alluxio.grpc.BlockMasterInfoField
 
getNumber() - Method in enum alluxio.grpc.ChannelAuthenticationScheme
 
getNumber() - Method in enum alluxio.grpc.CommandType
 
getNumber() - Method in enum alluxio.grpc.ConfigStatus
 
getNumber() - Method in enum alluxio.grpc.ErrorType
 
getNumber() - Method in enum alluxio.grpc.JobMasterMetaCommand
 
getNumber() - Method in enum alluxio.grpc.JobProgressReportFormat
 
getNumber() - Method in enum alluxio.grpc.JobSource
 
getNumber() - Method in enum alluxio.grpc.JobType
 
getNumber() - Method in enum alluxio.grpc.JournalDomain
 
getNumber() - Method in enum alluxio.grpc.ListStatusPartialPOptions.OffsetTypeCase
 
getNumber() - Method in enum alluxio.grpc.LoadDescendantPType
 
getNumber() - Method in enum alluxio.grpc.LoadMetadataPType
 
getNumber() - Method in enum alluxio.grpc.MasterInfoField
 
getNumber() - Method in enum alluxio.grpc.MetaCommand
 
getNumber() - Method in enum alluxio.grpc.MetricType
 
getNumber() - Method in enum alluxio.grpc.NodeState
 
getNumber() - Method in enum alluxio.grpc.OperationType
 
getNumber() - Method in enum alluxio.grpc.PAclAction
 
getNumber() - Method in enum alluxio.grpc.PAclEntryType
 
getNumber() - Method in enum alluxio.grpc.QuorumServerState
 
getNumber() - Method in enum alluxio.grpc.ReadPType
 
getNumber() - Method in enum alluxio.grpc.RequestType
 
getNumber() - Method in enum alluxio.grpc.SaslMessageType
 
getNumber() - Method in enum alluxio.grpc.Scope
 
getNumber() - Method in enum alluxio.grpc.ServiceType
 
getNumber() - Method in enum alluxio.grpc.SetAclAction
 
getNumber() - Method in enum alluxio.grpc.Status
 
getNumber() - Method in enum alluxio.grpc.SyncPointStatus
 
getNumber() - Method in enum alluxio.grpc.table.ColumnStatisticsData.DataCase
 
getNumber() - Method in enum alluxio.grpc.table.Domain.ValueSetCase
 
getNumber() - Method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
 
getNumber() - Method in enum alluxio.grpc.table.PrincipalType
 
getNumber() - Method in enum alluxio.grpc.table.TableInfo.TableType
 
getNumber() - Method in enum alluxio.grpc.table.Value.ValueCase
 
getNumber() - Method in enum alluxio.grpc.TaskStatus
 
getNumber() - Method in enum alluxio.grpc.TtlAction
 
getNumber() - Method in enum alluxio.grpc.UfsPMode
 
getNumber() - Method in enum alluxio.grpc.WorkerInfoField
 
getNumber() - Method in enum alluxio.grpc.WorkerRange
 
getNumber() - Method in enum alluxio.grpc.WritePType
 
getNumber() - Method in enum alluxio.grpc.WriteRequest.ValueCase
 
getNumber() - Method in enum alluxio.grpc.XAttrPropagationStrategy
 
getNumber() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getNumber() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getNumber() - Method in enum alluxio.proto.journal.File.PSetAclAction
 
getNumber() - Method in enum alluxio.proto.journal.File.PTtlAction
 
getNumber() - Method in enum alluxio.proto.journal.File.UfsMode
 
getNumber() - Method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
 
getNumber() - Method in enum alluxio.proto.journal.Job.PJobState
 
getNumber() - Method in enum alluxio.proto.shared.Acl.AclAction
 
getNumber() - Method in enum alluxio.proto.shared.Acl.AclEntryType
 
getNumber() - Method in enum alluxio.proto.status.Status.PStatus
 
getNumberOfBlocks() - Method in interface alluxio.worker.block.BlockStoreMeta
Note: This is only available when blocks are included.
getNumberOfBlocks() - Method in class alluxio.worker.block.BlockWorkerMetrics
 
getNumberOfDependents() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the estimated number of CompletableFutures whose completions are awaiting completion of this CompletableFuture.
getNumBuckets() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
getNumBuckets() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
 
getNumBuckets() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
getNumBuckets() - Method in class alluxio.master.file.meta.TtlBucketList
 
getNumBucketsPerSegment() - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
 
getNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData
optional int64 num_distincts = 4;
getNumDistincts() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional int64 num_distincts = 4;
getNumDistincts() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional int64 num_distincts = 4;
getNumDistincts() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 num_distincts = 4;
getNumDistincts() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_distincts = 4;
getNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData
optional int64 num_distincts = 4;
getNumDistincts() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
getNumEvents() - Method in class alluxio.time.ExponentialTimer
 
getNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_falses = 2;
getNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional int64 num_falses = 2;
getNumFalses() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional int64 num_falses = 2;
getNumInodes() - Method in class alluxio.master.file.meta.TtlBucketList
 
getNumLocks() - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
 
getNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional int64 num_nulls = 3;
getNumNulls() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional int64 num_nulls = 3;
getNumNulls() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData
optional int64 num_nulls = 3;
getNumNulls() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional int64 num_nulls = 3;
getNumNulls() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional int64 num_nulls = 3;
getNumNulls() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 num_nulls = 3;
getNumNulls() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_nulls = 3;
getNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData
optional int64 num_nulls = 3;
getNumNulls() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
getNumSector(String, String) - Static method in class alluxio.util.HFSUtils
Converts the memory size to number of sectors.
getNumSinks() - Static method in class alluxio.metrics.MetricsSystem
 
getNumSuccess() - Method in class alluxio.stress.cli.Benchmark.MethodStatistics
 
getNumTagsPerBuckets() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
 
getNumTagsPerBuckets() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
getNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_trues = 1;
getNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional int64 num_trues = 1;
getNumTrues() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional int64 num_trues = 1;
getObject() - Method in class alluxio.proxy.s3.S3Handler
Get the object name of this request.
getObject() - Method in class alluxio.worker.s3.S3NettyHandler
Get the object name of this request.
getObjectHeaderSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the fixed overhead of for any Object subclass in this JVM.
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getObjectListingChunk(ListObjectsRequest) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getObjectListingChunk(String, String, String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
getObjectListingChunk(String, boolean, String, int) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets a (partial) object listing result for the given key.
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets a (partial) object listing result for the given key.
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getObjectListingChunk(ListObjectsRequest) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getObjectListingChunk(ListObjectsRequest) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getObjectListingChunk(String, boolean, String, int) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getObjectListingChunkForPath(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getObjectListingChunkForPath(String, boolean, String, int) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets a (partial) object listing for the given path.
getObjectMetadata(String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Retrieves an object's metadata.
getObjectName() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getObjectOrListParts(String, String, String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Downloads an object or list parts of the object in multipart upload.
getObjectPadding() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the quantum field size for a field owned by an object in this JVM.
getObjectSize(Object) - Static method in class alluxio.util.ObjectSizeCalculator
Given an object, returns the total allocated size, in bytes, of the object and all other objects reachable from it.
getObjectSize(Object, Set<Class<?>>) - Static method in class alluxio.util.ObjectSizeCalculator
Given an object, returns the total allocated size, in bytes, of the object and all other objects reachable from it.
getObjectStatus(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Get metadata information about object.
getObjectStatus(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getObjectStatus(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getObjectStatuses() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Returns objects in a pseudo-directory which may be a file or a directory.
getObjectStatuses() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
 
getObjectStatuses() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunkV1
 
getObjectTaskResource() - Method in class alluxio.proxy.s3.S3ObjectTask
Concatenate bucket and object to make a full path.
getObjectTaskResource() - Method in class alluxio.worker.s3.S3NettyObjectTask
Concatenate bucket and object to make a full path.
getOffset() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional int64 offset = 2;
getOffset() - Method in class alluxio.grpc.FileBlockInfo
optional int64 offset = 2;
getOffset() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
optional int64 offset = 2;
getOffset() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 offset = 2;
getOffset() - Method in class alluxio.grpc.ReadRequest
optional int64 offset = 2;
getOffset() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 offset = 2;
getOffset() - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
getOffset() - Method in class alluxio.grpc.SnapshotData
Deprecated. 
getOffset() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
Deprecated. 
getOffset() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 offset = 3;
getOffset() - Method in class alluxio.grpc.WriteRequestCommand
optional int64 offset = 3;
getOffset() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional int64 offset = 3;
getOffset() - Method in class alluxio.grpc.WriteResponse.Builder
optional int64 offset = 1;
getOffset() - Method in class alluxio.grpc.WriteResponse
optional int64 offset = 1;
getOffset() - Method in interface alluxio.grpc.WriteResponseOrBuilder
optional int64 offset = 1;
getOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
getOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 offset = 2;
getOffset() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 offset = 2;
getOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
getOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int64 offset = 3;
getOffset() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int64 offset = 3;
getOffset(long) - Method in class alluxio.s3.S3RangeSpec
Get real offset of object.
getOffset() - Method in class alluxio.underfs.options.FileLocationOptions
 
getOffset() - Method in class alluxio.underfs.options.OpenOptions
 
getOffset() - Method in class alluxio.wire.FileBlockInfo
 
getOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only start listing items after this many items have been processed.
getOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions
Only start listing items after this many items have been processed.
getOffsetCount() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Only start listing items after this many items have been processed.
getOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
getOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
getOffsetId() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
getOffsetInFile() - Method in class alluxio.grpc.Block.Builder
The offset of the block in within ufs the file.
getOffsetInFile() - Method in class alluxio.grpc.Block
The offset of the block in within ufs the file.
getOffsetInFile() - Method in interface alluxio.grpc.BlockOrBuilder
The offset of the block in within ufs the file.
getOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The offset of the block in within the file.
getOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
The offset of the block in within the file.
getOffsetInFile() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
The offset of the block in within the file.
getOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated. 
getOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated. 
getOffsetReceived() - Method in interface alluxio.grpc.DownloadSnapshotPRequestOrBuilder
Deprecated. 
getOffsetReceived() - Method in class alluxio.grpc.ReadRequest.Builder
Read receipt
getOffsetReceived() - Method in class alluxio.grpc.ReadRequest
Read receipt
getOffsetReceived() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Read receipt
getOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated. 
getOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated. 
getOffsetReceived() - Method in interface alluxio.grpc.UploadSnapshotPResponseOrBuilder
Deprecated. 
getOffsetTypeCase() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
getOffsetTypeCase() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
getOffsetTypeCase() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
 
getOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
If set, only reserve space for the block.
getOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
If set, only reserve space for the block.
getOnlyReserveSpace() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
If set, only reserve space for the block.
getOnTierPercentages() - Method in class alluxio.util.webui.UIFileInfo
Gets on-tier percentages.
getOpenAction(int) - Static method in class alluxio.fuse.AlluxioFuseOpenUtils
Gets Alluxio Fuse open action based on open flag.
getOpenFileHandleContainer() - Method in class alluxio.worker.dora.PagedDoraWorker
 
getOpenOrCreateFlags() - Method in class alluxio.fuse.file.FuseFileEntry
 
getOpenUfsBlockOptions(long) - Method in class alluxio.client.file.options.InStreamOptions
 
getOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
getOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest
This is only set for UFS block read.
getOpenUfsBlockOptions() - Method in interface alluxio.grpc.ReadRequestOrBuilder
This is only set for UFS block read.
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
getOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
This is only set for UFS block read.
getOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
This is only set for UFS block read.
getOpenUfsBlockOptions() - Method in class alluxio.wire.BlockReadRequest
 
getOpenUfsBlockOptions() - Method in class alluxio.worker.netty.BlockReadRequest
 
getOpenUfsBlockOptionsBuilder() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsBuilder() - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsBuilder() - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
getOpenUfsBlockOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.CacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.grpc.ReadRequest
This is only set for UFS block read.
getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.grpc.ReadRequestOrBuilder
This is only set for UFS block read.
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
getOpenUfsBlockOptionsOrBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
This is only set for UFS block read.
getOpenUfsBlockOptionsOrBuilder() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
This is only set for UFS block read.
getOperation() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string operation = 1;
getOperation() - Method in class alluxio.grpc.AddPolicyPOptions
optional string operation = 1;
getOperation() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string operation = 1;
getOperationBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string operation = 1;
getOperationBytes() - Method in class alluxio.grpc.AddPolicyPOptions
optional string operation = 1;
getOperationBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string operation = 1;
getOperationContext() - Method in class alluxio.master.file.RpcContext
 
getOperationCount() - Method in class alluxio.wire.WorkerWebUIOperations
Gets the operation count.
getOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
getOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional .alluxio.grpc.file.FsOpPId operationId = 4;
getOperationId() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
getOperationId() - Method in class alluxio.master.file.contexts.CompleteFileContext
 
getOperationId() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
 
getOperationId() - Method in class alluxio.master.file.contexts.CreateFileContext
 
getOperationId() - Method in class alluxio.master.file.contexts.DeleteContext
 
getOperationId() - Method in class alluxio.master.file.contexts.OperationContext
Get embedded operation id, passed via proto options.
getOperationId() - Method in class alluxio.master.file.contexts.RenameContext
 
getOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
getOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
getOperationId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
getOperationIdBuilder() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
getOperationIdBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
getOperationIdOrBuilder() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
getOperationIdOrBuilder() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional .alluxio.grpc.file.FsOpPId operationId = 4;
getOperationIdOrBuilder() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
getOperationIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
getOperationIdOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
getOperationIdOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
getOperationMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
Gets operation metrics.
getOperationMetrics() - Method in class alluxio.wire.WorkerWebUIMetrics
Gets operation metrics.
getOperationMode(Map<String, UfsMode>) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getOperationMode(Map<String, UfsMode>) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getOperationMode(Map<String, UfsMode>) - Method in interface alluxio.underfs.UnderFileSystem
An UnderFileSystem may be composed of one or more "physical UFS"s.
getOperationMode(Map<String, UfsMode>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getOperationTimeMs() - Method in class alluxio.master.file.contexts.CompleteFileContext
 
getOperationTimeMs() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getOperationTimeMs() - Method in class alluxio.master.file.contexts.RenameContext
 
getOperationTimeMs() - Method in class alluxio.master.file.contexts.SetAttributeContext
 
getOperationType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional .alluxio.grpc.job.OperationType operationType = 3;
getOperationType() - Method in class alluxio.grpc.CmdStatusBlock
optional .alluxio.grpc.job.OperationType operationType = 3;
getOperationType() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
optional .alluxio.grpc.job.OperationType operationType = 3;
getOperationType() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.OperationType operationType = 2;
getOperationType() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.OperationType operationType = 2;
getOperationType() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.OperationType operationType = 2;
getOperationType() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getOperationType() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
getOperationType() - Method in interface alluxio.job.CmdConfig
 
getOperationType() - Method in class alluxio.job.wire.CmdStatusBlock
Get OperationType.
getOperationType() - Method in class alluxio.master.job.common.CmdInfo
Get operation type.
getOpId() - Method in class alluxio.master.file.RpcContext
gets op id.
getOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 op_time_ms = 4;
getOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 op_time_ms = 4;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 op_time_ms = 4;
getOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 op_time_ms = 3;
getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 op_time_ms = 2;
getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry
optional int64 op_time_ms = 2;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional int64 op_time_ms = 2;
getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
getOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 op_time_ms = 2;
getOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 op_time_ms = 2;
getOptionList() - Method in class alluxio.cli.AbstractValidationTask
 
getOptionList() - Method in class alluxio.cli.hdfs.HdfsConfParityValidationTask
 
getOptionList() - Method in interface alluxio.cli.ValidationTask
 
getOptionName() - Method in class alluxio.fuse.options.BaseValueConverter
 
getOptions() - Method in interface alluxio.cli.Command
 
getOptions() - Method in class alluxio.cli.fs.command.CheckCachedCommand
 
getOptions() - Method in class alluxio.cli.fs.command.ChgrpCommand
 
getOptions() - Method in class alluxio.cli.fs.command.ChmodCommand
 
getOptions() - Method in class alluxio.cli.fs.command.ChownCommand
 
getOptions() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
 
getOptions() - Method in class alluxio.cli.fs.command.CpCommand
 
getOptions() - Method in class alluxio.cli.fs.command.FreeCommand
 
getOptions() - Method in class alluxio.cli.fs.command.HeadCommand
 
getOptions() - Method in class alluxio.cli.fs.command.LoadCommand
 
getOptions() - Method in class alluxio.cli.fs.command.LsCommand
 
getOptions() - Method in class alluxio.cli.fs.command.RmCommand
 
getOptions() - Method in class alluxio.cli.fs.command.StatCommand
 
getOptions() - Method in class alluxio.cli.fs.command.TailCommand
 
getOptions() - Method in class alluxio.cli.fs.command.TestCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
getOptions() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
getOptions() - Method in class alluxio.client.file.options.InStreamOptions
 
getOptions() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
getOptions() - Method in class alluxio.grpc.AddPolicyPRequest
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
getOptions() - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
getOptions() - Method in class alluxio.grpc.BackupPRequest
optional .alluxio.grpc.meta.BackupPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
getOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
getOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
getOptions() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
getOptions() - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CancelPRequest
optional .alluxio.grpc.job.CancelPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
optional .alluxio.grpc.job.CancelPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CheckAccessPRequest
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
getOptions() - Method in class alluxio.grpc.CommitBlockPRequest
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
getOptions() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
getOptions() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
getOptions() - Method in class alluxio.grpc.CompleteFilePRequest
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
getOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
getOptions() - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
getOptions() - Method in class alluxio.grpc.CreateFilePRequest
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
getOptions() - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
getOptions() - Method in class alluxio.grpc.DeletePRequest
optional .alluxio.grpc.file.DeletePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
optional .alluxio.grpc.file.DeletePOptions options = 2;
getOptions() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
getOptions() - Method in class alluxio.grpc.ExistsPRequest
optional .alluxio.grpc.file.ExistsPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
getOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
getOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
getOptions() - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
getOptions() - Method in class alluxio.grpc.FreePRequest
optional .alluxio.grpc.file.FreePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.FreePRequestOrBuilder
optional .alluxio.grpc.file.FreePOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
getOptions() - Method in class alluxio.grpc.GetActionInfoRequest
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
getOptions() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
getOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.GetAllMasterStatusPRequestOrBuilder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.GetAllWorkerHealthPRequestOrBuilder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetCmdStatusRequest
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetFileInfoPRequest
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobProgressPRequest
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.GetJobServiceSummaryPRequestOrBuilder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetJobStatusPRequest
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetMasterIdPRequest
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.GetPinnedFileIdsPRequestOrBuilder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.GetQuorumInfoPRequestOrBuilder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
getOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
getOptions() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
getOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.GetStateLockHoldersPRequestOrBuilder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
getOptions() - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetStatusPRequest
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
getOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
getOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
getOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
getOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
getOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
getOptions() - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListAllPRequest
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.ListAllPRequestOrBuilder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListPolicyPRequest
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.ListPolicyPRequestOrBuilder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.ListProxyStatusPRequestOrBuilder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
getOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
getOptions() - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.ListStatusPRequest
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
getOptions() - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptions() - Method in class alluxio.grpc.LoadFileRequest
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptions() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptions() - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptions() - Method in class alluxio.grpc.LoadRequest
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptions() - Method in interface alluxio.grpc.LoadRequestOrBuilder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
getOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
getOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
getOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.MetricsHeartbeatPRequestOrBuilder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
getOptions() - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptions() - Method in class alluxio.grpc.MountPRequest
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.MountPRequestOrBuilder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
getOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
getOptions() - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptions() - Method in class alluxio.grpc.PolicyInfo
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptions() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.ProxyHeartbeatPRequestOrBuilder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
getOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RegisterMasterPRequest
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
getOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
getOptions() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
getOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
getOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
getOptions() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RemovePolicyPRequest
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
getOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
getOptions() - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
getOptions() - Method in class alluxio.grpc.RenamePRequest
optional .alluxio.grpc.file.RenamePOptions options = 3;
getOptions() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
optional .alluxio.grpc.file.RenamePOptions options = 3;
getOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
getOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.ResetPrioritiesPRequestOrBuilder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
getOptions() - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
getOptions() - Method in class alluxio.grpc.RunPRequest
optional .alluxio.grpc.job.RunPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.RunPRequestOrBuilder
optional .alluxio.grpc.job.RunPOptions options = 2;
getOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
getOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
getOptions() - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
getOptions() - Method in class alluxio.grpc.SetAclPRequest
the method options
getOptions() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the method options
getOptions() - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
getOptions() - Method in class alluxio.grpc.SetAttributePRequest
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
getOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
getOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
getOptions() - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
getOptions() - Method in class alluxio.grpc.SubmitRequest
optional .alluxio.grpc.job.SubmitOptions options = 2;
getOptions() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
optional .alluxio.grpc.job.SubmitOptions options = 2;
getOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
Deprecated.
getOptions() - Method in class alluxio.grpc.table.AttachDatabasePRequest
Deprecated.
getOptions() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
Deprecated.
getOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
getOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
getOptions() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
getOptions() - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
getOptions() - Method in class alluxio.grpc.UnmountPRequest
optional .alluxio.grpc.file.UnmountPOptions options = 2;
getOptions() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
getOptions() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptions() - Method in class alluxio.grpc.UpdateMountPRequest
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptions() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
getOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
getOptions() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
getOptions() - Method in class alluxio.job.CopyJobRequest
 
getOptions() - Method in class alluxio.job.LoadJobRequest
 
getOptions() - Method in class alluxio.job.MoveJobRequest
 
getOptions() - Method in class alluxio.master.file.contexts.OperationContext
 
getOptions() - Method in class alluxio.master.file.meta.options.MountInfo
 
getOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptions() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptions() - Method in class alluxio.util.UnixMountInfo
 
getOptions() - Method in class alluxio.worker.dora.OpenFileHandle
Get Alluxio create file options.
getOptionsBuilder() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
getOptionsBuilder() - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
getOptionsBuilder() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
getOptionsBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
getOptionsBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
getOptionsBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
getOptionsBuilder() - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
getOptionsBuilder() - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
getOptionsBuilder() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsBuilder() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
getOptionsBuilder() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsCount() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
getOptionsCount() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
getOptionsCount() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
map<string, string> options = 5;
getOptionsMap() - Method in class alluxio.fuse.options.MountCliOptions
 
getOptionsMap() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
getOptionsMap() - Method in class alluxio.grpc.table.AttachDatabasePRequest
map<string, string> options = 5;
getOptionsMap() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
map<string, string> options = 5;
getOptionsOrBuilder() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.AddPolicyPRequest
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.BackupPRequest
optional .alluxio.grpc.meta.BackupPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
getOptionsOrBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
getOptionsOrBuilder() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
getOptionsOrBuilder() - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CancelPRequest
optional .alluxio.grpc.job.CancelPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
optional .alluxio.grpc.job.CancelPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CheckAccessPRequest
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CheckConsistencyPRequest
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
getOptionsOrBuilder() - Method in class alluxio.grpc.CommitBlockPRequest
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
getOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CompleteFilePRequest
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CreateDirectoryPRequest
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.CreateFilePRequest
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.DeletePRequest
optional .alluxio.grpc.file.DeletePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
optional .alluxio.grpc.file.DeletePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ExistsPRequest
optional .alluxio.grpc.file.ExistsPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.FreePRequest
optional .alluxio.grpc.file.FreePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.FreePRequestOrBuilder
optional .alluxio.grpc.file.FreePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetActionInfoRequest
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetAllMasterStatusPRequestOrBuilder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetAllWorkerHealthPRequestOrBuilder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetBlockInfoPRequest
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetCmdStatusRequest
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetFileInfoPRequest
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobServiceSummaryPRequestOrBuilder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetJobStatusPRequest
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetPinnedFileIdsPRequestOrBuilder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPRequest
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetQuorumInfoPRequest
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetQuorumInfoPRequestOrBuilder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetStateLockHoldersPRequestOrBuilder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetStatusPRequest
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPRequest
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListAllPRequest
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ListAllPRequestOrBuilder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListPolicyPRequest
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ListPolicyPRequestOrBuilder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListProxyStatusPRequest
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ListProxyStatusPRequestOrBuilder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPOptions
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPartialPRequest
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ListStatusPRequest
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.LoadFileRequest
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.LoadRequest
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.LoadRequestOrBuilder
required .alluxio.grpc.block.UfsReadOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.MasterHeartbeatPRequest
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.MetricsHeartbeatPRequestOrBuilder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.MountPRequest
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.MountPRequestOrBuilder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsOrBuilder() - Method in class alluxio.grpc.PolicyInfo
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsOrBuilder() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ProxyHeartbeatPRequestOrBuilder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPRequest
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterMasterPRequest
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
getOptionsOrBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RemovePolicyPRequest
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.RenamePRequest
optional .alluxio.grpc.file.RenamePOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
optional .alluxio.grpc.file.RenamePOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.ResetPrioritiesPRequest
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ResetPrioritiesPRequestOrBuilder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.RunPRequest
optional .alluxio.grpc.job.RunPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.RunPRequestOrBuilder
optional .alluxio.grpc.job.RunPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
getOptionsOrBuilder() - Method in class alluxio.grpc.SetAclPRequest
the method options
getOptionsOrBuilder() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the method options
getOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.SetAttributePRequest
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.SetPathConfigurationPRequest
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.SubmitRequest
optional .alluxio.grpc.job.SubmitOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
optional .alluxio.grpc.job.SubmitOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
getOptionsOrBuilder() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
getOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.UnmountPRequest
optional .alluxio.grpc.file.UnmountPOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateMountPRequest
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsOrBuilder() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
optional .alluxio.grpc.file.MountPOptions options = 3;
getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.grpc.UpdateUfsModePRequest
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
getOptionsOrBuilder() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
getOptionsOrBuilder() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsOrBuilder() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsOrBuilder() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
getOptionsOrDefault(String, String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
getOptionsOrDefault(String, String) - Method in class alluxio.grpc.table.AttachDatabasePRequest
map<string, string> options = 5;
getOptionsOrDefault(String, String) - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
map<string, string> options = 5;
getOptionsOrThrow(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
getOptionsOrThrow(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest
map<string, string> options = 5;
getOptionsOrThrow(String) - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
map<string, string> options = 5;
getOPType() - Method in class alluxio.proxy.s3.S3BaseTask
Return the OpType (S3 API enum).
getOPType() - Method in class alluxio.worker.s3.S3NettyBaseTask
Return the OpType (S3 API enum).
getOrAdd(AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
Return a UFS instance if it already exists in the cache, otherwise, creates a new instance and return it.
getOrBuildCustom(String) - Static method in class alluxio.conf.PropertyKey
 
getOrDefault(PropertyKey, T) - Method in interface alluxio.conf.AlluxioConfiguration
 
getOrDefault(PropertyKey, Object, ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
 
getOrDefault(PropertyKey, T) - Static method in class alluxio.conf.Configuration
 
getOrDefault(PropertyKey, String, ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
 
getOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
getOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
getOrder() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
getOrderedStorageAliases() - Method in class alluxio.DefaultStorageTierAssoc
 
getOrderedStorageAliases() - Method in interface alluxio.StorageTierAssoc
 
getOrderedTierAliases() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets ordered tier aliases.
getOrdinal(String) - Method in class alluxio.DefaultStorageTierAssoc
 
getOrdinal(String) - Method in interface alluxio.StorageTierAssoc
 
getOrNull() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
 
getOSSClient() - Method in class alluxio.underfs.oss.StsOssClientProvider
Returns the STS OSS client.
getOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
getOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional .alluxio.proto.shared.AclActions otherActions = 6;
getOtherActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional .alluxio.proto.shared.AclActions otherActions = 6;
getOtherActions() - Method in class alluxio.security.authorization.AccessControlList
 
getOtherActionsBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
getOtherActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
getOtherActionsOrBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional .alluxio.proto.shared.AclActions otherActions = 6;
getOtherActionsOrBuilder() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional .alluxio.proto.shared.AclActions otherActions = 6;
getOtherBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits otherBits = 3;
getOtherBits() - Method in class alluxio.grpc.PMode
required .alluxio.grpc.Bits otherBits = 3;
getOtherBits() - Method in interface alluxio.grpc.PModeOrBuilder
required .alluxio.grpc.Bits otherBits = 3;
getOtherBits() - Method in class alluxio.security.authorization.Mode
 
getOut() - Method in class alluxio.fuse.CreateFileEntry
Gets the opened output stream for this open file entry.
getOut() - Method in class alluxio.fuse.OpenFileEntry
Gets the opened output stream for this open file entry.
getOutput() - Method in class alluxio.shell.CommandReturn
Gets the stdout content.
getOutputDirectory() - Method in class alluxio.master.backcompat.BackwardsCompatibilityJournalGenerator
 
getOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string output_format = 3;
getOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string output_format = 3;
getOutputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string output_format = 3;
getOutputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string output_format = 3;
getOutputFormatBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string output_format = 3;
getOutputFormatBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string output_format = 3;
getOutputStream() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
getOutputStream() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
getOutStream(AlluxioURI, FileSystemContext, OutStreamOptions, FileOutStream, String) - Method in class alluxio.client.file.dora.DoraCacheClient
Get a stream to write the data to dora cache cluster.
getOutStream(Integer) - Method in class alluxio.StreamCache
 
getOutStream() - Method in class alluxio.worker.dora.OpenFileHandle
Get UFS out stream of this handle.
getOverheadRatio() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getOverheadRatio() - Method in enum alluxio.client.file.cache.store.PageStoreType
 
getOverriddenMethodDescriptors() - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
getOverwrite() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool overwrite = 4;
getOverwrite() - Method in class alluxio.grpc.CopyJobPOptions
optional bool overwrite = 4;
getOverwrite() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool overwrite = 4;
getOverwrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool overwrite = 13;
getOverwrite() - Method in class alluxio.grpc.CreateFilePOptions
optional bool overwrite = 13;
getOverwrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool overwrite = 13;
getOverwrite() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool overwrite = 4;
getOverwrite() - Method in class alluxio.grpc.MoveJobPOptions
optional bool overwrite = 4;
getOverwrite() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool overwrite = 4;
getOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool overwrite = 1;
getOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions
optional bool overwrite = 1;
getOverwrite() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
optional bool overwrite = 1;
getOverwrite() - Method in class alluxio.grpc.WriteOptions.Builder
optional bool overwrite = 1;
getOverwrite() - Method in class alluxio.grpc.WriteOptions
optional bool overwrite = 1;
getOverwrite() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
optional bool overwrite = 1;
getOverWrite() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool overwrite = 10;
getOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional bool overwrite = 10;
getOverwrite() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional bool overwrite = 10;
getOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool overwrite = 10;
getOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional bool overwrite = 10;
getOverwrite() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional bool overwrite = 10;
getOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_access_time = 19;
getOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional bool overwrite_access_time = 19;
getOverwriteAccessTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional bool overwrite_access_time = 19;
getOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_modification_time = 8;
getOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional bool overwrite_modification_time = 8;
getOverwriteModificationTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional bool overwrite_modification_time = 8;
getOwner() - Method in class alluxio.client.file.options.OutStreamOptions
 
getOwner() - Method in class alluxio.client.file.URIStatus
 
getOwner() - Method in class alluxio.grpc.FileInfo.Builder
optional string owner = 16;
getOwner() - Method in class alluxio.grpc.FileInfo
optional string owner = 16;
getOwner() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string owner = 16;
getOwner() - Method in class alluxio.grpc.PAcl.Builder
optional string owner = 1;
getOwner() - Method in class alluxio.grpc.PAcl
optional string owner = 1;
getOwner() - Method in interface alluxio.grpc.PAclOrBuilder
optional string owner = 1;
getOwner() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string owner = 3;
getOwner() - Method in class alluxio.grpc.SetAttributePOptions
optional string owner = 3;
getOwner() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional string owner = 3;
getOwner() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string owner = 4;
getOwner() - Method in class alluxio.grpc.table.TableInfo
optional string owner = 4;
getOwner() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string owner = 4;
getOwner() - Method in class alluxio.grpc.UfsStatus.Builder
optional string owner = 4;
getOwner() - Method in class alluxio.grpc.UfsStatus
optional string owner = 4;
getOwner() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string owner = 4;
getOwner() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getOwner() - Method in class alluxio.master.file.meta.Inode
 
getOwner() - Method in interface alluxio.master.file.meta.InodeView
 
getOwner() - Method in class alluxio.master.file.meta.MutableInode
 
getOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
getOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string owner = 2;
getOwner() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string owner = 2;
getOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
getOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string owner = 8;
getOwner() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string owner = 8;
getOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
getOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string owner = 14;
getOwner() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string owner = 14;
getOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
getOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string owner = 6;
getOwner() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string owner = 6;
getOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string owner = 9;
getOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string owner = 9;
getOwner() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string owner = 9;
getOwner() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getOwner() - Method in class alluxio.underfs.options.CreateOptions
 
getOwner() - Method in class alluxio.underfs.options.MkdirsOptions
 
getOwner() - Method in class alluxio.underfs.UfsStatus
Gets the owner of the given path.
getOwner(UserState) - Static method in class alluxio.util.SecurityUtils
 
getOwner() - Method in class alluxio.util.webui.UIFileInfo
Gets owner.
getOwner() - Method in class alluxio.wire.FileInfo
 
getOwnerBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits ownerBits = 1;
getOwnerBits() - Method in class alluxio.grpc.PMode
required .alluxio.grpc.Bits ownerBits = 1;
getOwnerBits() - Method in interface alluxio.grpc.PModeOrBuilder
required .alluxio.grpc.Bits ownerBits = 1;
getOwnerBits() - Method in class alluxio.security.authorization.Mode
 
getOwnerBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string owner = 16;
getOwnerBytes() - Method in class alluxio.grpc.FileInfo
optional string owner = 16;
getOwnerBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string owner = 16;
getOwnerBytes() - Method in class alluxio.grpc.PAcl.Builder
optional string owner = 1;
getOwnerBytes() - Method in class alluxio.grpc.PAcl
optional string owner = 1;
getOwnerBytes() - Method in interface alluxio.grpc.PAclOrBuilder
optional string owner = 1;
getOwnerBytes() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string owner = 3;
getOwnerBytes() - Method in class alluxio.grpc.SetAttributePOptions
optional string owner = 3;
getOwnerBytes() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional string owner = 3;
getOwnerBytes() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string owner = 4;
getOwnerBytes() - Method in class alluxio.grpc.table.TableInfo
optional string owner = 4;
getOwnerBytes() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string owner = 4;
getOwnerBytes() - Method in class alluxio.grpc.UfsStatus.Builder
optional string owner = 4;
getOwnerBytes() - Method in class alluxio.grpc.UfsStatus
optional string owner = 4;
getOwnerBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string owner = 4;
getOwnerBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
getOwnerBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string owner = 2;
getOwnerBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string owner = 2;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string owner = 8;
getOwnerBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string owner = 8;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
getOwnerBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string owner = 14;
getOwnerBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string owner = 14;
getOwnerBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
getOwnerBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string owner = 6;
getOwnerBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string owner = 6;
getOwnerBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string owner = 9;
getOwnerBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string owner = 9;
getOwnerBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string owner = 9;
getOwnerFromGrpcClient(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
 
getOwnerName() - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
getOwnerName() - Method in class alluxio.grpc.table.Database
optional string owner_name = 5;
getOwnerName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string owner_name = 5;
getOwnerNameBytes() - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
getOwnerNameBytes() - Method in class alluxio.grpc.table.Database
optional string owner_name = 5;
getOwnerNameBytes() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string owner_name = 5;
getOwnerType() - Method in class alluxio.grpc.table.Database.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
getOwnerType() - Method in class alluxio.grpc.table.Database
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
getOwnerType() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
getOwningGroup() - Method in class alluxio.grpc.PAcl.Builder
optional string owningGroup = 2;
getOwningGroup() - Method in class alluxio.grpc.PAcl
optional string owningGroup = 2;
getOwningGroup() - Method in interface alluxio.grpc.PAclOrBuilder
optional string owningGroup = 2;
getOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningGroup = 2;
getOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional string owningGroup = 2;
getOwningGroup() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional string owningGroup = 2;
getOwningGroup() - Method in class alluxio.security.authorization.AccessControlList
 
getOwningGroupActions() - Method in class alluxio.security.authorization.AccessControlList
 
getOwningGroupBytes() - Method in class alluxio.grpc.PAcl.Builder
optional string owningGroup = 2;
getOwningGroupBytes() - Method in class alluxio.grpc.PAcl
optional string owningGroup = 2;
getOwningGroupBytes() - Method in interface alluxio.grpc.PAclOrBuilder
optional string owningGroup = 2;
getOwningGroupBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningGroup = 2;
getOwningGroupBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional string owningGroup = 2;
getOwningGroupBytes() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional string owningGroup = 2;
getOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningUser = 1;
getOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional string owningUser = 1;
getOwningUser() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional string owningUser = 1;
getOwningUser() - Method in class alluxio.security.authorization.AccessControlList
 
getOwningUserActions() - Method in class alluxio.security.authorization.AccessControlList
 
getOwningUserBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningUser = 1;
getOwningUserBytes() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional string owningUser = 1;
getOwningUserBytes() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional string owningUser = 1;
getPackets() - Method in class alluxio.worker.netty.WriteRequestContext
 
getPacketSize() - Method in class alluxio.worker.netty.ReadRequest
 
getPacketWriteException() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
Get the exception object that created during packet writing.
getPage(String, long, Channel) - Method in class alluxio.worker.http.PagedService
Get page bytes given fileId, pageIndex, and channel which is used for allocating ByteBuf.
getPageFileRegion(String, long) - Method in class alluxio.worker.http.PagedService
Get FileRegion object given fileId, pageIndex, and channel.
getPageId() - Method in class alluxio.client.file.cache.PageInfo
 
getPageIndex() - Method in class alluxio.client.file.cache.PageId
 
getPageInfo(PageId) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
getPageInfo(PageId) - Method in interface alluxio.client.file.cache.PageMetaStore
 
getPageInfo(PageId) - Method in class alluxio.client.file.cache.QuotaPageMetaStore
 
getPageLockId(PageId) - Method in class alluxio.client.file.cache.LocalCacheManager
 
getPagePath(PageId, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
getPageSize() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
getPageSize() - Method in class alluxio.client.file.cache.LocalCachePositionReader
Get the page size.
getPageSize() - Method in class alluxio.client.file.cache.PageInfo
 
getPageSize() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 pageSize = 1;
getPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
optional int64 pageSize = 1;
getPageSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
optional int64 pageSize = 1;
getPageStore() - Method in class alluxio.client.file.cache.store.LocalPageStoreDir
Getter for pageStore.
getPageStore() - Method in class alluxio.client.file.cache.store.MemoryPageStoreDir
 
getPageStore() - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
getPageStoreOptions() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
getParallelism() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the targeted parallelism level of this pool.
getParameter() - Method in class alluxio.grpc.table.Database.Builder
Deprecated.
getParameter() - Method in class alluxio.grpc.table.Database
Deprecated.
getParameter() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
Deprecated.
getParameterCount() - Method in class alluxio.grpc.table.Database.Builder
 
getParameterCount() - Method in class alluxio.grpc.table.Database
 
getParameterCount() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
map<string, string> parameter = 4;
getParameterMap() - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
getParameterMap() - Method in class alluxio.grpc.table.Database
map<string, string> parameter = 4;
getParameterMap() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
map<string, string> parameter = 4;
getParameterOrDefault(String, String) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
getParameterOrDefault(String, String) - Method in class alluxio.grpc.table.Database
map<string, string> parameter = 4;
getParameterOrDefault(String, String) - Method in interface alluxio.grpc.table.DatabaseOrBuilder
map<string, string> parameter = 4;
getParameterOrThrow(String) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
getParameterOrThrow(String) - Method in class alluxio.grpc.table.Database
map<string, string> parameter = 4;
getParameterOrThrow(String) - Method in interface alluxio.grpc.table.DatabaseOrBuilder
map<string, string> parameter = 4;
getParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
Deprecated.
getParameters() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
Deprecated.
getParameters() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
Deprecated.
getParameters() - Method in class alluxio.grpc.table.TableInfo.Builder
Deprecated.
getParameters() - Method in class alluxio.grpc.table.TableInfo
Deprecated.
getParameters() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
Deprecated.
getParameters() - Method in class alluxio.stress.client.ClientIOSummary
 
getParameters() - Method in class alluxio.stress.client.ClientIOTaskResult
 
getParameters() - Method in class alluxio.stress.worker.IOTaskResult
 
getParameters() - Method in class alluxio.stress.worker.IOTaskSummary
 
getParameters() - Method in class alluxio.stress.worker.WorkerBenchSummary
 
getParameters() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getParameters() - Method in class alluxio.worker.http.HttpRequestUri
Get the parameters map.
getParametersCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
getParametersCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
getParametersCount() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
map<string, string> parameters = 7;
getParametersCount() - Method in class alluxio.grpc.table.TableInfo.Builder
 
getParametersCount() - Method in class alluxio.grpc.table.TableInfo
 
getParametersCount() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
map<string, string> parameters = 7;
getParametersMap() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
map<string, string> parameters = 7;
getParametersMap() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
map<string, string> parameters = 7;
getParametersMap() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
map<string, string> parameters = 7;
getParametersMap() - Method in class alluxio.grpc.table.TableInfo.Builder
map<string, string> parameters = 7;
getParametersMap() - Method in class alluxio.grpc.table.TableInfo
map<string, string> parameters = 7;
getParametersMap() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.TableInfo.Builder
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in class alluxio.grpc.table.TableInfo
map<string, string> parameters = 7;
getParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in class alluxio.grpc.table.TableInfo.Builder
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in class alluxio.grpc.table.TableInfo
map<string, string> parameters = 7;
getParametersOrThrow(String) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
map<string, string> parameters = 7;
getParent() - Method in class alluxio.AlluxioURI
Get the parent of this AlluxioURI or null if at root.
getParent(String) - Static method in class alluxio.util.io.PathUtils
Gets the parent of the file at a path.
getParentCleaned(String) - Static method in class alluxio.util.io.PathUtils
The same as PathUtils.getParent(java.lang.String) except does not clean the path before getting the parent.
getParentCommandName() - Method in class alluxio.cli.command.AbstractFuseShellCommand
Gets the parent command name.
getParentDir() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getParentDir() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getParentId() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 parentId = 10;
getParentId() - Method in class alluxio.grpc.JobInfo
optional int64 parentId = 10;
getParentId() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional int64 parentId = 10;
getParentId() - Method in interface alluxio.job.wire.JobInfo
 
getParentId() - Method in class alluxio.job.wire.PlanInfo
 
getParentId() - Method in class alluxio.job.wire.TaskInfo
 
getParentId() - Method in class alluxio.job.wire.WorkflowInfo
 
getParentId() - Method in class alluxio.master.file.meta.EdgeEntry
 
getParentId() - Method in class alluxio.master.file.meta.Inode
 
getParentId() - Method in interface alluxio.master.file.meta.InodeView
 
getParentId() - Method in class alluxio.master.file.meta.MutableInode
 
getParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 parent_id = 2;
getParentId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 parent_id = 2;
getParentId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 parent_id = 2;
getParentId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 parent_id = 2;
getParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 parent_id = 7;
getParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 parent_id = 7;
getParentId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 parent_id = 7;
getParentInodeDirectory() - Method in class alluxio.master.file.meta.LockedInodePath
 
getParentInodeOrNull() - Method in class alluxio.master.file.meta.LockedInodePath
 
getParentPath(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Get parent path.
getParents(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads for the given nodes parents.
getParents() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the parent nodes of the node.
getParentSubject() - Method in class alluxio.grpc.GrpcChannelBuilder
 
getParentTier() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the StorageTier containing this StorageDir.
getParsedFingerprint(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getParsedFingerprint(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getParsedFingerprint(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getParsedFingerprint(String, String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getParsedFingerprint(String) - Method in interface alluxio.underfs.UnderFileSystem
Computes and returns a fingerprint for the path.
getParsedFingerprint(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Same as UnderFileSystem.getParsedFingerprint(String) except, will use the given content hash as the Fingerprint.Tag.CONTENT_HASH field of the fingerprint if non-null.
getParsedFingerprint(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getParsedFingerprint(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getParserForType() - Method in class alluxio.grpc.ActionInfo
 
getParserForType() - Method in class alluxio.grpc.AddPolicyPOptions
 
getParserForType() - Method in class alluxio.grpc.AddPolicyPRequest
 
getParserForType() - Method in class alluxio.grpc.AddPolicyPResponse
 
getParserForType() - Method in class alluxio.grpc.AddQuorumServerRequest
 
getParserForType() - Method in class alluxio.grpc.AsyncCacheRequest
 
getParserForType() - Method in class alluxio.grpc.AsyncCacheResponse
 
getParserForType() - Method in class alluxio.grpc.BackupPOptions
 
getParserForType() - Method in class alluxio.grpc.BackupPRequest
 
getParserForType() - Method in class alluxio.grpc.BackupPStatus
 
getParserForType() - Method in class alluxio.grpc.BackupStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.Block
 
getParserForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
getParserForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
getParserForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
getParserForType() - Method in class alluxio.grpc.BlockIdList
 
getParserForType() - Method in class alluxio.grpc.BlockInfo
 
getParserForType() - Method in class alluxio.grpc.BlockLocation
 
getParserForType() - Method in class alluxio.grpc.BlockMasterInfo
 
getParserForType() - Method in class alluxio.grpc.BlockStatus
 
getParserForType() - Method in class alluxio.grpc.BlockStoreLocationProto
 
getParserForType() - Method in class alluxio.grpc.BuildVersion
 
getParserForType() - Method in class alluxio.grpc.CacheRequest
 
getParserForType() - Method in class alluxio.grpc.CacheResponse
 
getParserForType() - Method in class alluxio.grpc.CancelPOptions
 
getParserForType() - Method in class alluxio.grpc.CancelPRequest
 
getParserForType() - Method in class alluxio.grpc.CancelPResponse
 
getParserForType() - Method in class alluxio.grpc.CancelTaskCommand
 
getParserForType() - Method in class alluxio.grpc.CheckAccessPOptions
 
getParserForType() - Method in class alluxio.grpc.CheckAccessPRequest
 
getParserForType() - Method in class alluxio.grpc.CheckAccessPResponse
 
getParserForType() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
getParserForType() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
getParserForType() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
getParserForType() - Method in class alluxio.grpc.CheckpointPOptions
 
getParserForType() - Method in class alluxio.grpc.CheckpointPResponse
 
getParserForType() - Method in class alluxio.grpc.CheckRequest
 
getParserForType() - Method in class alluxio.grpc.CheckResponse
 
getParserForType() - Method in class alluxio.grpc.Chunk
 
getParserForType() - Method in class alluxio.grpc.ClearMetricsPRequest
 
getParserForType() - Method in class alluxio.grpc.ClearMetricsPResponse
 
getParserForType() - Method in class alluxio.grpc.ClearMetricsRequest
 
getParserForType() - Method in class alluxio.grpc.ClearMetricsResponse
 
getParserForType() - Method in class alluxio.grpc.ClientMetrics
 
getParserForType() - Method in class alluxio.grpc.CmdProgress
 
getParserForType() - Method in class alluxio.grpc.CmdStatusBlock
 
getParserForType() - Method in class alluxio.grpc.CmdSummary
 
getParserForType() - Method in class alluxio.grpc.Command
 
getParserForType() - Method in class alluxio.grpc.CommitBlockPOptions
 
getParserForType() - Method in class alluxio.grpc.CommitBlockPRequest
 
getParserForType() - Method in class alluxio.grpc.CommitBlockPResponse
 
getParserForType() - Method in class alluxio.grpc.CompleteFilePOptions
 
getParserForType() - Method in class alluxio.grpc.CompleteFilePRequest
 
getParserForType() - Method in class alluxio.grpc.CompleteFilePResponse
 
getParserForType() - Method in class alluxio.grpc.ConfigCheckReport
 
getParserForType() - Method in class alluxio.grpc.ConfigProperties
 
getParserForType() - Method in class alluxio.grpc.ConfigProperty
 
getParserForType() - Method in class alluxio.grpc.CopyJobPOptions
 
getParserForType() - Method in class alluxio.grpc.CopyRequest
 
getParserForType() - Method in class alluxio.grpc.CopyResponse
 
getParserForType() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
getParserForType() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
getParserForType() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
getParserForType() - Method in class alluxio.grpc.CreateFilePOptions
 
getParserForType() - Method in class alluxio.grpc.CreateFilePRequest
 
getParserForType() - Method in class alluxio.grpc.CreateFilePResponse
 
getParserForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
getParserForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
getParserForType() - Method in class alluxio.grpc.DeletePOptions
 
getParserForType() - Method in class alluxio.grpc.DeletePRequest
 
getParserForType() - Method in class alluxio.grpc.DeletePResponse
 
getParserForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.ErrorInfo
 
getParserForType() - Method in class alluxio.grpc.ExistsPOptions
 
getParserForType() - Method in class alluxio.grpc.ExistsPRequest
 
getParserForType() - Method in class alluxio.grpc.ExistsPResponse
 
getParserForType() - Method in class alluxio.grpc.File
 
getParserForType() - Method in class alluxio.grpc.FileBlockInfo
 
getParserForType() - Method in class alluxio.grpc.FileFailure
 
getParserForType() - Method in class alluxio.grpc.FileInfo
 
getParserForType() - Method in class alluxio.grpc.FileSystemCommand
 
getParserForType() - Method in class alluxio.grpc.FileSystemCommandOptions
 
getParserForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
getParserForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
getParserForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
getParserForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
getParserForType() - Method in class alluxio.grpc.FreePOptions
 
getParserForType() - Method in class alluxio.grpc.FreePRequest
 
getParserForType() - Method in class alluxio.grpc.FreePResponse
 
getParserForType() - Method in class alluxio.grpc.FreeWorkerRequest
 
getParserForType() - Method in class alluxio.grpc.FreeWorkerResponse
 
getParserForType() - Method in class alluxio.grpc.FsOpPId
 
getParserForType() - Method in class alluxio.grpc.GetActionInfoOptions
 
getParserForType() - Method in class alluxio.grpc.GetActionInfoRequest
 
getParserForType() - Method in class alluxio.grpc.GetActionInfoResponse
 
getParserForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
getParserForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
getParserForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
getParserForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
getParserForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
getParserForType() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
getParserForType() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
getParserForType() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
getParserForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
getParserForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
getParserForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
getParserForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
getParserForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
getParserForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
getParserForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
getParserForType() - Method in class alluxio.grpc.GetCmdStatusOptions
 
getParserForType() - Method in class alluxio.grpc.GetCmdStatusRequest
 
getParserForType() - Method in class alluxio.grpc.GetCmdStatusResponse
 
getParserForType() - Method in class alluxio.grpc.GetConfigHashPOptions
 
getParserForType() - Method in class alluxio.grpc.GetConfigHashPResponse
 
getParserForType() - Method in class alluxio.grpc.GetConfigReportPOptions
 
getParserForType() - Method in class alluxio.grpc.GetConfigReportPResponse
 
getParserForType() - Method in class alluxio.grpc.GetConfigurationPOptions
 
getParserForType() - Method in class alluxio.grpc.GetConfigurationPResponse
 
getParserForType() - Method in class alluxio.grpc.GetFileInfoPOptions
 
getParserForType() - Method in class alluxio.grpc.GetFileInfoPRequest
 
getParserForType() - Method in class alluxio.grpc.GetFileInfoPResponse
 
getParserForType() - Method in class alluxio.grpc.GetFilePathPRequest
 
getParserForType() - Method in class alluxio.grpc.GetFilePathPResponse
 
getParserForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
getParserForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
getParserForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
getParserForType() - Method in class alluxio.grpc.GetJobProgressPRequest
 
getParserForType() - Method in class alluxio.grpc.GetJobProgressPResponse
 
getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getParserForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
getParserForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
getParserForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
getParserForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
getParserForType() - Method in class alluxio.grpc.GetJobStatusPOptions
 
getParserForType() - Method in class alluxio.grpc.GetJobStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.GetJobStatusPResponse
 
getParserForType() - Method in class alluxio.grpc.GetMasterIdPOptions
 
getParserForType() - Method in class alluxio.grpc.GetMasterIdPRequest
 
getParserForType() - Method in class alluxio.grpc.GetMasterIdPResponse
 
getParserForType() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
getParserForType() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
getParserForType() - Method in class alluxio.grpc.GetMetricsPOptions
 
getParserForType() - Method in class alluxio.grpc.GetMetricsPResponse
 
getParserForType() - Method in class alluxio.grpc.GetMountIdPRequest
 
getParserForType() - Method in class alluxio.grpc.GetMountIdPResponse
 
getParserForType() - Method in class alluxio.grpc.GetMountTablePRequest
 
getParserForType() - Method in class alluxio.grpc.GetMountTablePResponse
 
getParserForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
getParserForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
getParserForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
getParserForType() - Method in class alluxio.grpc.GetNodeStatePRequest
 
getParserForType() - Method in class alluxio.grpc.GetNodeStatePResponse
 
getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getParserForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
getParserForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
getParserForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
getParserForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
getParserForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
getParserForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
getParserForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
getParserForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
getParserForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
getParserForType() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
getParserForType() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
getParserForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
getParserForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
getParserForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
getParserForType() - Method in class alluxio.grpc.GetStatusPOptions
 
getParserForType() - Method in class alluxio.grpc.GetStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.GetStatusPResponse
 
getParserForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
getParserForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
getParserForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
getParserForType() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
getParserForType() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
getParserForType() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
getParserForType() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
getParserForType() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
getParserForType() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
getParserForType() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
getParserForType() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
getParserForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
getParserForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
getParserForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
getParserForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
getParserForType() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
getParserForType() - Method in class alluxio.grpc.InconsistentProperties
 
getParserForType() - Method in class alluxio.grpc.InconsistentProperty
 
getParserForType() - Method in class alluxio.grpc.InconsistentPropertyValues
 
getParserForType() - Method in class alluxio.grpc.JobCommand
 
getParserForType() - Method in class alluxio.grpc.JobDescription
 
getParserForType() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
getParserForType() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
getParserForType() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
getParserForType() - Method in class alluxio.grpc.JobInfo
 
getParserForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
getParserForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
getParserForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
getParserForType() - Method in class alluxio.grpc.JobMasterStatus
 
getParserForType() - Method in class alluxio.grpc.JobProgress
 
getParserForType() - Method in class alluxio.grpc.JobProgressPOptions
 
getParserForType() - Method in class alluxio.grpc.JobServiceSummary
 
getParserForType() - Method in class alluxio.grpc.JobStatusBlock
 
getParserForType() - Method in class alluxio.grpc.JobUnused
 
getParserForType() - Method in class alluxio.grpc.JobWorkerHealth
 
getParserForType() - Method in class alluxio.grpc.JournalQueryRequest
 
getParserForType() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
getParserForType() - Method in class alluxio.grpc.ListAllPOptions
 
getParserForType() - Method in class alluxio.grpc.ListAllPRequest
 
getParserForType() - Method in class alluxio.grpc.ListAllPResponse
 
getParserForType() - Method in class alluxio.grpc.ListPolicyPOptions
 
getParserForType() - Method in class alluxio.grpc.ListPolicyPRequest
 
getParserForType() - Method in class alluxio.grpc.ListPolicyPResponse
 
getParserForType() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
getParserForType() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
getParserForType() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
getParserForType() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
getParserForType() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
getParserForType() - Method in class alluxio.grpc.ListStatusPOptions
 
getParserForType() - Method in class alluxio.grpc.ListStatusPRequest
 
getParserForType() - Method in class alluxio.grpc.ListStatusPResponse
 
getParserForType() - Method in class alluxio.grpc.LoadFileFailure
 
getParserForType() - Method in class alluxio.grpc.LoadFileRequest
 
getParserForType() - Method in class alluxio.grpc.LoadFileResponse
 
getParserForType() - Method in class alluxio.grpc.LoadJobPOptions
 
getParserForType() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getParserForType() - Method in class alluxio.grpc.LoadRequest
 
getParserForType() - Method in class alluxio.grpc.LoadResponse
 
getParserForType() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
getParserForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
getParserForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
getParserForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
getParserForType() - Method in class alluxio.grpc.MasterInfo
 
getParserForType() - Method in class alluxio.grpc.MasterVersion
 
getParserForType() - Method in class alluxio.grpc.MessagingRequestHeader
 
getParserForType() - Method in class alluxio.grpc.MessagingResponseHeader
 
getParserForType() - Method in class alluxio.grpc.Metric
 
getParserForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
getParserForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
getParserForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
getParserForType() - Method in class alluxio.grpc.MetricValue
 
getParserForType() - Method in class alluxio.grpc.MountPointInfo
 
getParserForType() - Method in class alluxio.grpc.MountPOptions
 
getParserForType() - Method in class alluxio.grpc.MountPRequest
 
getParserForType() - Method in class alluxio.grpc.MountPResponse
 
getParserForType() - Method in class alluxio.grpc.MoveBlockRequest
 
getParserForType() - Method in class alluxio.grpc.MoveBlockResponse
 
getParserForType() - Method in class alluxio.grpc.MoveJobPOptions
 
getParserForType() - Method in class alluxio.grpc.MoveRequest
 
getParserForType() - Method in class alluxio.grpc.MoveResponse
 
getParserForType() - Method in class alluxio.grpc.NeedsSyncRequest
 
getParserForType() - Method in class alluxio.grpc.NeedsSyncResponse
 
getParserForType() - Method in class alluxio.grpc.NetAddress
 
getParserForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
getParserForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
getParserForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
getParserForType() - Method in class alluxio.grpc.OpenFilePOptions
 
getParserForType() - Method in class alluxio.grpc.PAcl
 
getParserForType() - Method in class alluxio.grpc.PAclEntry
 
getParserForType() - Method in class alluxio.grpc.PersistCommandOptions
 
getParserForType() - Method in class alluxio.grpc.PersistFile
 
getParserForType() - Method in class alluxio.grpc.PMode
 
getParserForType() - Method in class alluxio.grpc.PolicyInfo
 
getParserForType() - Method in class alluxio.grpc.PolicyStatus
 
getParserForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
getParserForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
getParserForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
getParserForType() - Method in class alluxio.grpc.ProxyStatus
 
getParserForType() - Method in class alluxio.grpc.QuorumServerInfo
 
getParserForType() - Method in class alluxio.grpc.ReadRequest
 
getParserForType() - Method in class alluxio.grpc.ReadResponse
 
getParserForType() - Method in class alluxio.grpc.RegisterCommand
 
getParserForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
getParserForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
getParserForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
getParserForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
getParserForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
getParserForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
getParserForType() - Method in class alluxio.grpc.RegisterMasterPOptions
 
getParserForType() - Method in class alluxio.grpc.RegisterMasterPRequest
 
getParserForType() - Method in class alluxio.grpc.RegisterMasterPResponse
 
getParserForType() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
getParserForType() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getParserForType() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
getParserForType() - Method in class alluxio.grpc.RemoveBlockRequest
 
getParserForType() - Method in class alluxio.grpc.RemoveBlockResponse
 
getParserForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
getParserForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getParserForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
getParserForType() - Method in class alluxio.grpc.RemovePolicyPOptions
 
getParserForType() - Method in class alluxio.grpc.RemovePolicyPRequest
 
getParserForType() - Method in class alluxio.grpc.RemovePolicyPResponse
 
getParserForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
getParserForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
getParserForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
getParserForType() - Method in class alluxio.grpc.RenamePOptions
 
getParserForType() - Method in class alluxio.grpc.RenamePRequest
 
getParserForType() - Method in class alluxio.grpc.RenamePResponse
 
getParserForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
getParserForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
getParserForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
getParserForType() - Method in class alluxio.grpc.RetryInfo
 
getParserForType() - Method in class alluxio.grpc.ReverseResolvePRequest
 
getParserForType() - Method in class alluxio.grpc.ReverseResolvePResponse
 
getParserForType() - Method in class alluxio.grpc.Route
 
getParserForType() - Method in class alluxio.grpc.RouteFailure
 
getParserForType() - Method in class alluxio.grpc.RunPOptions
 
getParserForType() - Method in class alluxio.grpc.RunPRequest
 
getParserForType() - Method in class alluxio.grpc.RunPResponse
 
getParserForType() - Method in class alluxio.grpc.RunTaskCommand
 
getParserForType() - Method in class alluxio.grpc.S3SyntaxOptions
 
getParserForType() - Method in class alluxio.grpc.SaslMessage
 
getParserForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
getParserForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
getParserForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
getParserForType() - Method in class alluxio.grpc.SetAclPOptions
 
getParserForType() - Method in class alluxio.grpc.SetAclPRequest
 
getParserForType() - Method in class alluxio.grpc.SetAclPResponse
 
getParserForType() - Method in class alluxio.grpc.SetAttributePOptions
 
getParserForType() - Method in class alluxio.grpc.SetAttributePRequest
 
getParserForType() - Method in class alluxio.grpc.SetAttributePResponse
 
getParserForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
getParserForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
getParserForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
getParserForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
getParserForType() - Method in class alluxio.grpc.SnapshotData
 
getParserForType() - Method in class alluxio.grpc.SnapshotMetadata
 
getParserForType() - Method in class alluxio.grpc.StatusSummary
 
getParserForType() - Method in class alluxio.grpc.StopJobPRequest
 
getParserForType() - Method in class alluxio.grpc.StopJobPResponse
 
getParserForType() - Method in class alluxio.grpc.StorageList
 
getParserForType() - Method in class alluxio.grpc.SubmitJobPRequest
 
getParserForType() - Method in class alluxio.grpc.SubmitJobPResponse
 
getParserForType() - Method in class alluxio.grpc.SubmitOptions
 
getParserForType() - Method in class alluxio.grpc.SubmitRequest
 
getParserForType() - Method in class alluxio.grpc.SubmitResponse
 
getParserForType() - Method in class alluxio.grpc.table.AllOrNoneSet
 
getParserForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
getParserForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
getParserForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
getParserForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
getParserForType() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
getParserForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
getParserForType() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
getParserForType() - Method in class alluxio.grpc.table.Constraint
 
getParserForType() - Method in class alluxio.grpc.table.Database
 
getParserForType() - Method in class alluxio.grpc.table.Date
 
getParserForType() - Method in class alluxio.grpc.table.DateColumnStatsData
 
getParserForType() - Method in class alluxio.grpc.table.Decimal
 
getParserForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
getParserForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
getParserForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
getParserForType() - Method in class alluxio.grpc.table.Domain
 
getParserForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
getParserForType() - Method in class alluxio.grpc.table.EquatableValueSet
 
getParserForType() - Method in class alluxio.grpc.table.FieldSchema
 
getParserForType() - Method in class alluxio.grpc.table.FileStatistics
 
getParserForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
getParserForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
getParserForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
getParserForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
getParserForType() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
getParserForType() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
getParserForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
getParserForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
getParserForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
getParserForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
getParserForType() - Method in class alluxio.grpc.table.GetTablePRequest
 
getParserForType() - Method in class alluxio.grpc.table.GetTablePResponse
 
getParserForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
getParserForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
getParserForType() - Method in class alluxio.grpc.table.Layout
 
getParserForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
getParserForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
getParserForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
getParserForType() - Method in class alluxio.grpc.table.layout.hive.Storage
 
getParserForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
getParserForType() - Method in class alluxio.grpc.table.LayoutSpec
 
getParserForType() - Method in class alluxio.grpc.table.LongColumnStatsData
 
getParserForType() - Method in class alluxio.grpc.table.Partition
 
getParserForType() - Method in class alluxio.grpc.table.PartitionSpec
 
getParserForType() - Method in class alluxio.grpc.table.Range
 
getParserForType() - Method in class alluxio.grpc.table.RangeSet
 
getParserForType() - Method in class alluxio.grpc.table.ReadTablePRequest
 
getParserForType() - Method in class alluxio.grpc.table.ReadTablePResponse
 
getParserForType() - Method in class alluxio.grpc.table.Schema
 
getParserForType() - Method in class alluxio.grpc.table.StringColumnStatsData
 
getParserForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
getParserForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
getParserForType() - Method in class alluxio.grpc.table.SyncStatus
 
getParserForType() - Method in class alluxio.grpc.table.TableInfo
 
getParserForType() - Method in class alluxio.grpc.table.Transformation
 
getParserForType() - Method in class alluxio.grpc.table.TransformJobInfo
 
getParserForType() - Method in class alluxio.grpc.table.TransformTablePRequest
 
getParserForType() - Method in class alluxio.grpc.table.TransformTablePResponse
 
getParserForType() - Method in class alluxio.grpc.table.Value
 
getParserForType() - Method in class alluxio.grpc.TierList
 
getParserForType() - Method in class alluxio.grpc.TransferLeaderMessage
 
getParserForType() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
getParserForType() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
getParserForType() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
getParserForType() - Method in class alluxio.grpc.TransportMessage
 
getParserForType() - Method in class alluxio.grpc.TriggerPolicyRequest
 
getParserForType() - Method in class alluxio.grpc.TriggerPolicyResponse
 
getParserForType() - Method in class alluxio.grpc.UfsFileStatus
 
getParserForType() - Method in class alluxio.grpc.UfsInfo
 
getParserForType() - Method in class alluxio.grpc.UfsReadOptions
 
getParserForType() - Method in class alluxio.grpc.UfsStatus
 
getParserForType() - Method in class alluxio.grpc.UnmountPOptions
 
getParserForType() - Method in class alluxio.grpc.UnmountPRequest
 
getParserForType() - Method in class alluxio.grpc.UnmountPResponse
 
getParserForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
getParserForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
getParserForType() - Method in class alluxio.grpc.UpdateMountPRequest
 
getParserForType() - Method in class alluxio.grpc.UpdateMountPResponse
 
getParserForType() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
getParserForType() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
getParserForType() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
getParserForType() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
getParserForType() - Method in class alluxio.grpc.WorkerIdentity
 
getParserForType() - Method in class alluxio.grpc.WorkerInfo
 
getParserForType() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getParserForType() - Method in class alluxio.grpc.WorkerNetAddress
 
getParserForType() - Method in class alluxio.grpc.WriteOptions
 
getParserForType() - Method in class alluxio.grpc.WriteRequest
 
getParserForType() - Method in class alluxio.grpc.WriteRequestCommand
 
getParserForType() - Method in class alluxio.grpc.WriteResponse
 
getParserForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
getParserForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getParserForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getParserForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getParserForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getParserForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.RenameEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.SetAclEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.StringPairEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
getParserForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getParserForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
getParserForType() - Method in class alluxio.proto.journal.Job.FileFilter
 
getParserForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
getParserForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
getParserForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
getParserForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
getParserForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
getParserForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
getParserForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
getParserForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
getParserForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
getParserForType() - Method in class alluxio.proto.meta.Block.BlockLocation
 
getParserForType() - Method in class alluxio.proto.meta.Block.BlockMeta
 
getParserForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
getParserForType() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
getParserForType() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
getParserForType() - Method in class alluxio.proto.shared.Acl.AclActions
 
getParserForType() - Method in class alluxio.proto.shared.Acl.AclEntry
 
getParserForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
getPartialListing() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool partialListing = 3;
getPartialListing() - Method in class alluxio.grpc.CopyJobPOptions
optional bool partialListing = 3;
getPartialListing() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool partialListing = 3;
getPartialListing() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool partialListing = 3;
getPartialListing() - Method in class alluxio.grpc.LoadJobPOptions
optional bool partialListing = 3;
getPartialListing() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool partialListing = 3;
getPartialListing() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool partialListing = 3;
getPartialListing() - Method in class alluxio.grpc.MoveJobPOptions
optional bool partialListing = 3;
getPartialListing() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool partialListing = 3;
getPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool partialListing = 7;
getPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required bool partialListing = 7;
getPartialListing() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required bool partialListing = 7;
getPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool partialListing = 6;
getPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required bool partialListing = 6;
getPartialListing() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required bool partialListing = 6;
getPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool partialListing = 7;
getPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required bool partialListing = 7;
getPartialListing() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required bool partialListing = 7;
getPartialOptions() - Method in class alluxio.master.file.contexts.ListStatusContext
 
getPartition() - Method in class alluxio.client.hive.HiveCacheContext
 
getPartitionCols(int) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionCols(int) - Method in class alluxio.grpc.table.TableInfo
partitioning scheme
getPartitionCols(int) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
partitioning scheme
getPartitionColsBuilder(int) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsBuilderList() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsCount() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsCount() - Method in class alluxio.grpc.table.TableInfo
partitioning scheme
getPartitionColsCount() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
partitioning scheme
getPartitionColsList() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsList() - Method in class alluxio.grpc.table.TableInfo
partitioning scheme
getPartitionColsList() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
partitioning scheme
getPartitionColsOrBuilder(int) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsOrBuilder(int) - Method in class alluxio.grpc.table.TableInfo
partitioning scheme
getPartitionColsOrBuilder(int) - Method in interface alluxio.grpc.table.TableInfoOrBuilder
partitioning scheme
getPartitionColsOrBuilderList() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
getPartitionColsOrBuilderList() - Method in class alluxio.grpc.table.TableInfo
partitioning scheme
getPartitionColsOrBuilderList() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
partitioning scheme
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getPartitionColumnStatistics(String, String, List<String>, List<String>) - Method in interface alluxio.client.table.TableMasterClient
Get column statistics for selected partition and column.
getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest, StreamObserver<GetPartitionColumnStatisticsPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
 
getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
 
getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
 
getPartitionColumnStatistics(GetPartitionColumnStatisticsPRequest, StreamObserver<GetPartitionColumnStatisticsPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
GetPartitionColumnStatisticsPRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
GetPartitionColumnStatisticsPRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
GetPartitionColumnStatisticsPRequestOrBuilder - Interface in alluxio.grpc.table
 
GetPartitionColumnStatisticsPResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
GetPartitionColumnStatisticsPResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
GetPartitionColumnStatisticsPResponseOrBuilder - Interface in alluxio.grpc.table
 
getPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
partition name in the form of "key=value"
getPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
partition name in the form of "key=value"
getPartitionName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
partition name in the form of "key=value"
getPartitionNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
partition name in the form of "key=value"
getPartitionNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
partition name in the form of "key=value"
getPartitionNameBytes() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
partition name in the form of "key=value"
getPartitionNames(String, String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getPartitionNames(String, String) - Method in interface alluxio.client.table.TableMasterClient
Get partition names with given database name and table name.
getPartitions(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitions(int) - Method in class alluxio.grpc.table.ReadTablePResponse
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitions(int) - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsBuilderList() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsCount() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsCount() - Method in class alluxio.grpc.table.ReadTablePResponse
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsCount() - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsList() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsList() - Method in class alluxio.grpc.table.ReadTablePResponse
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsList() - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsOrBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsOrBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsOrBuilder(int) - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsOrBuilderList() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsOrBuilderList() - Method in class alluxio.grpc.table.ReadTablePResponse
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionsOrBuilderList() - Method in interface alluxio.grpc.table.ReadTablePResponseOrBuilder
repeated .alluxio.grpc.table.Partition partitions = 1;
getPartitionSpec() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
getPartitionSpec() - Method in class alluxio.grpc.table.Partition
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
getPartitionSpec() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
getPartitionSpecBuilder() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
getPartitionSpecOrBuilder() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
getPartitionSpecOrBuilder() - Method in class alluxio.grpc.table.Partition
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
getPartitionSpecOrBuilder() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
getPartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
Deprecated.
getPartitionStatistics() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
Deprecated.
getPartitionStatistics() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
Deprecated.
getPartitionStatisticsCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
getPartitionStatisticsCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
getPartitionStatisticsCount() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsMap() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsMap() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsMap() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsOrDefault(String, ColumnStatisticsList) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsOrDefault(String, ColumnStatisticsList) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsOrDefault(String, ColumnStatisticsList) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsOrThrow(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsOrThrow(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartitionStatisticsOrThrow(String) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPResponseOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
getPartNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
getPartNames(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string part_names = 4;
getPartNames(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string part_names = 4;
getPartNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
getPartNamesBytes(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string part_names = 4;
getPartNamesBytes(int) - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string part_names = 4;
getPartNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
getPartNamesCount() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string part_names = 4;
getPartNamesCount() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string part_names = 4;
getPartNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
getPartNamesList() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
repeated string part_names = 4;
getPartNamesList() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
repeated string part_names = 4;
getPartNumber() - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
 
getPartNumber() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getPartNumber() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
Get the part number.
getParts() - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest
 
getParts() - Method in class alluxio.proxy.s3.ListPartsResult
 
getPath() - Method in class alluxio.AlluxioURI
Gets the path component of the AlluxioURI.
getPath() - Method in class alluxio.client.file.URIStatus
For example, for the uri: alluxio://host:1000/foo/bar/baz, the path is /foo/bar/baz.
getPath() - Method in class alluxio.fuse.CreateFileEntry
 
getPath() - Method in class alluxio.fuse.file.FuseFileEntry
 
getPath() - Method in class alluxio.fuse.OpenFileEntry
 
getPath() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.CheckAccessPRequest
optional string path = 1;
getPath() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
the root of the subtree to check
getPath() - Method in class alluxio.grpc.CheckConsistencyPRequest
the root of the subtree to check
getPath() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
the root of the subtree to check
getPath() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
the path of the file
getPath() - Method in class alluxio.grpc.CompleteFilePRequest
the path of the file
getPath() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
the path of the file
getPath() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
the path of the directory
getPath() - Method in class alluxio.grpc.CreateDirectoryPRequest
the path of the directory
getPath() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
the path of the directory
getPath() - Method in class alluxio.grpc.CreateFilePRequest.Builder
the path of the file
getPath() - Method in class alluxio.grpc.CreateFilePRequest
the path of the file
getPath() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
the path of the file
getPath() - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
getPath() - Method in class alluxio.grpc.DeletePRequest
the path of the file or directory
getPath() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
the path of the file or directory
getPath() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.ExistsPRequest
optional string path = 1;
getPath() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.grpc.FileInfo.Builder
optional string path = 3;
getPath() - Method in class alluxio.grpc.FileInfo
optional string path = 3;
getPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string path = 3;
getPath() - Method in class alluxio.grpc.FreePRequest.Builder
the path of the file or directory
getPath() - Method in class alluxio.grpc.FreePRequest
the path of the file or directory
getPath() - Method in interface alluxio.grpc.FreePRequestOrBuilder
the path of the file or directory
getPath() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.GetFilePathPResponse
optional string path = 1;
getPath() - Method in interface alluxio.grpc.GetFilePathPResponseOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
the path of the file
getPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
the path of the file
getPath() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
the path of the file
getPath() - Method in class alluxio.grpc.GetStatusPRequest.Builder
the path of the file or directory
getPath() - Method in class alluxio.grpc.GetStatusPRequest
the path of the file or directory
getPath() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
the path of the file or directory
getPath() - Method in class alluxio.grpc.JobDescription.Builder
optional string path = 2;
getPath() - Method in class alluxio.grpc.JobDescription
optional string path = 2;
getPath() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
optional string path = 2;
getPath() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
the path of the file or directory
getPath() - Method in class alluxio.grpc.ListStatusPartialPRequest
the path of the file or directory
getPath() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
the path of the file or directory
getPath() - Method in class alluxio.grpc.ListStatusPRequest.Builder
the path of the file or directory
getPath() - Method in class alluxio.grpc.ListStatusPRequest
the path of the file or directory
getPath() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
the path of the file or directory
getPath() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
required string path = 1;
getPath() - Method in class alluxio.grpc.NeedsSyncRequest
required string path = 1;
getPath() - Method in interface alluxio.grpc.NeedsSyncRequestOrBuilder
required string path = 1;
getPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
optional string path = 1;
getPath() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.grpc.RenamePRequest.Builder
the source path of the file or directory
getPath() - Method in class alluxio.grpc.RenamePRequest
the source path of the file or directory
getPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
the source path of the file or directory
getPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
the path of the file
getPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
the path of the file
getPath() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
the path of the file
getPath() - Method in class alluxio.grpc.SetAclPRequest.Builder
the path of the file or directory
getPath() - Method in class alluxio.grpc.SetAclPRequest
the path of the file or directory
getPath() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the path of the file or directory
getPath() - Method in class alluxio.grpc.SetAttributePRequest.Builder
the path of the file
getPath() - Method in class alluxio.grpc.SetAttributePRequest
the path of the file
getPath() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
the path of the file
getPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional string path = 1;
getPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest
optional string path = 1;
getPath() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.job.JobDescription
 
getPath() - Method in class alluxio.job.LoadJobRequest
 
getPath(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getPath(long) - Method in interface alluxio.master.file.FileSystemMaster
Gets the path of a file with the given id.
getPath(long) - Method in class alluxio.master.file.meta.FileSystemMasterView
Gets the path of a file with the given id.
getPath(long) - Method in class alluxio.master.file.meta.InodeTree
Returns the path for a particular inode id.
getPath(InodeView) - Method in class alluxio.master.file.meta.InodeTree
Returns the path for a particular inode.
getPath() - Method in class alluxio.master.file.meta.LockingScheme
 
getPath() - Method in class alluxio.master.job.DoraLoadJob
Get load file path.
getPath() - Method in class alluxio.master.job.LoadJob
Get load file path.
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
optional string path = 1;
getPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
getPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
optional string path = 1;
getPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional string path = 5;
getPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional string path = 5;
getPath() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional string path = 5;
getPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string path = 17;
getPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string path = 17;
getPath() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string path = 17;
getPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string path = 25;
getPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string path = 25;
getPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string path = 25;
getPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string path = 6;
getPath() - Method in class alluxio.proto.journal.File.RenameEntry
optional string path = 6;
getPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string path = 6;
getPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string path = 12;
getPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional string path = 12;
getPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional string path = 12;
getPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
optional string path = 1;
getPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
optional string path = 1;
getPath() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
optional string path = 1;
getPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
optional string path = 1;
getPath() - Method in interface alluxio.proto.journal.Meta.RemovePathPropertiesEntryOrBuilder
optional string path = 1;
getPath() - Method in class alluxio.uri.StandardURI
 
getPath() - Method in interface alluxio.uri.URI
 
getPath() - Method in class alluxio.wire.FileInfo
 
getPath() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets path.
getPath() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getPath() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getPath() - Method in class alluxio.worker.dora.OpenFileHandle
Get path of this handle.
getPathBytes() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.CheckAccessPRequest
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
the root of the subtree to check
getPathBytes() - Method in class alluxio.grpc.CheckConsistencyPRequest
the root of the subtree to check
getPathBytes() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
the root of the subtree to check
getPathBytes() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
the path of the file
getPathBytes() - Method in class alluxio.grpc.CompleteFilePRequest
the path of the file
getPathBytes() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
the path of the file
getPathBytes() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
the path of the directory
getPathBytes() - Method in class alluxio.grpc.CreateDirectoryPRequest
the path of the directory
getPathBytes() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
the path of the directory
getPathBytes() - Method in class alluxio.grpc.CreateFilePRequest.Builder
the path of the file
getPathBytes() - Method in class alluxio.grpc.CreateFilePRequest
the path of the file
getPathBytes() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
the path of the file
getPathBytes() - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.DeletePRequest
the path of the file or directory
getPathBytes() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.ExistsPRequest
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string path = 3;
getPathBytes() - Method in class alluxio.grpc.FileInfo
optional string path = 3;
getPathBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string path = 3;
getPathBytes() - Method in class alluxio.grpc.FreePRequest.Builder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.FreePRequest
the path of the file or directory
getPathBytes() - Method in interface alluxio.grpc.FreePRequestOrBuilder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.GetFilePathPResponse
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.GetFilePathPResponseOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
the path of the file
getPathBytes() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
the path of the file
getPathBytes() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
the path of the file
getPathBytes() - Method in class alluxio.grpc.GetStatusPRequest.Builder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.GetStatusPRequest
the path of the file or directory
getPathBytes() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.JobDescription.Builder
optional string path = 2;
getPathBytes() - Method in class alluxio.grpc.JobDescription
optional string path = 2;
getPathBytes() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
optional string path = 2;
getPathBytes() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.ListStatusPartialPRequest
the path of the file or directory
getPathBytes() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.ListStatusPRequest.Builder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.ListStatusPRequest
the path of the file or directory
getPathBytes() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
required string path = 1;
getPathBytes() - Method in class alluxio.grpc.NeedsSyncRequest
required string path = 1;
getPathBytes() - Method in interface alluxio.grpc.NeedsSyncRequestOrBuilder
required string path = 1;
getPathBytes() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.RenamePRequest.Builder
the source path of the file or directory
getPathBytes() - Method in class alluxio.grpc.RenamePRequest
the source path of the file or directory
getPathBytes() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
the source path of the file or directory
getPathBytes() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
the path of the file
getPathBytes() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
the path of the file
getPathBytes() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
the path of the file
getPathBytes() - Method in class alluxio.grpc.SetAclPRequest.Builder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.SetAclPRequest
the path of the file or directory
getPathBytes() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the path of the file or directory
getPathBytes() - Method in class alluxio.grpc.SetAttributePRequest.Builder
the path of the file
getPathBytes() - Method in class alluxio.grpc.SetAttributePRequest
the path of the file
getPathBytes() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
the path of the file
getPathBytes() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.grpc.SetPathConfigurationPRequest
optional string path = 1;
getPathBytes() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
optional string path = 1;
getPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
optional string path = 1;
getPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional string path = 5;
getPathBytes() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional string path = 5;
getPathBytes() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional string path = 5;
getPathBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string path = 17;
getPathBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string path = 17;
getPathBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string path = 17;
getPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string path = 25;
getPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string path = 25;
getPathBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string path = 25;
getPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string path = 6;
getPathBytes() - Method in class alluxio.proto.journal.File.RenameEntry
optional string path = 6;
getPathBytes() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string path = 6;
getPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string path = 12;
getPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional string path = 12;
getPathBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional string path = 12;
getPathBytes() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
optional string path = 1;
getPathBytes() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
optional string path = 1;
getPathBytes() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
optional string path = 1;
getPathBytes() - Method in interface alluxio.proto.journal.Meta.RemovePathPropertiesEntryOrBuilder
optional string path = 1;
getPathComponents(String) - Static method in class alluxio.util.io.PathUtils
Gets the path components of the given path.
getPathConf() - Method in class alluxio.wire.Configuration
 
getPathConfHash() - Method in class alluxio.wire.Configuration
 
getPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string pathConfigHash = 2;
getPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
optional string pathConfigHash = 2;
getPathConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
optional string pathConfigHash = 2;
getPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string pathConfigHash = 4;
getPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
optional string pathConfigHash = 4;
getPathConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional string pathConfigHash = 4;
getPathConfigHash() - Method in class alluxio.wire.ConfigHash
 
getPathConfigHash() - Method in class alluxio.wire.WorkerWebUIConfiguration
 
getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string pathConfigHash = 2;
getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigHashPResponse
optional string pathConfigHash = 2;
getPathConfigHashBytes() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
optional string pathConfigHash = 2;
getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string pathConfigHash = 4;
getPathConfigHashBytes() - Method in class alluxio.grpc.GetConfigurationPResponse
optional string pathConfigHash = 4;
getPathConfigHashBytes() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional string pathConfigHash = 4;
getPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 pathConfigLastUpdateTime = 6;
getPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
optional int64 pathConfigLastUpdateTime = 6;
getPathConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional int64 pathConfigLastUpdateTime = 6;
getPathConfigLastUpdateTime() - Method in class alluxio.wire.ConfigHash
 
getPathConfigLastUpdateTime() - Method in class alluxio.wire.WorkerWebUIConfiguration
 
getPathConfigLastUpdateTimeText() - Method in class alluxio.wire.ConfigHash
 
getPathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
Deprecated.
getPathConfigs() - Method in class alluxio.grpc.GetConfigurationPResponse
Deprecated.
getPathConfigs() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
Deprecated.
getPathConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
getPathConfigsCount() - Method in class alluxio.grpc.GetConfigurationPResponse
 
getPathConfigsCount() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsMap() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsMap() - Method in class alluxio.grpc.GetConfigurationPResponse
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsMap() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsOrDefault(String, ConfigProperties) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsOrDefault(String, ConfigProperties) - Method in class alluxio.grpc.GetConfigurationPResponse
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsOrDefault(String, ConfigProperties) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsOrThrow(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsOrThrow(String) - Method in class alluxio.grpc.GetConfigurationPResponse
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfigsOrThrow(String) - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
getPathConfLastUpdateTime() - Method in class alluxio.wire.Configuration
 
getPathInfos() - Method in class alluxio.wire.MasterWebUIBrowse
Get path infos ui file info [ ].
getPathInodeNames(InodeView) - Method in class alluxio.master.file.meta.InodeTree
Computes the path components for the given inode view.
getPathInodeNames(long) - Method in class alluxio.master.file.meta.InodeTree
Computes the path components for the given inode id.
getPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
getPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
getPathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
getPathPropertiesBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
getPathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
getPathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
getPathPropertiesOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
getPathResolverCache(AlluxioConfiguration, FuseOptions) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the cache for resolving FUSE path into AlluxioURI.
getPathStatus(FileSystem, AlluxioURI) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the path status.
getPathWithoutScheme(Path) - Static method in class alluxio.hadoop.HadoopUtils
Given a Path path, it returns the path component of its URI, which has the form scheme://authority/path.
getPattern() - Method in class alluxio.master.file.meta.LockingScheme
 
getPattern() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
optional string pattern = 2;
getPattern() - Method in class alluxio.proto.journal.Job.FileFilter
optional string pattern = 2;
getPattern() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
optional string pattern = 2;
getPatternBytes() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
optional string pattern = 2;
getPatternBytes() - Method in class alluxio.proto.journal.Job.FileFilter
optional string pattern = 2;
getPatternBytes() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
optional string pattern = 2;
getPayload() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the payload of the node.
getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCMessage
Returns the data buffer of the payload.
getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getPeerId(InetSocketAddress) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
Gets the raft peer id.
getPeerId(String, int) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
Gets the raft peer id.
getPendingCount() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the current pending count.
getPercentAvailable() - Method in class alluxio.wire.JournalDiskInfo
 
getPermanentFileName(String) - Static method in class alluxio.util.io.PathUtils
 
getPermission(LockedInodePath) - Method in class alluxio.master.file.DefaultPermissionChecker
 
getPermission(String, List<String>) - Method in class alluxio.master.file.meta.Inode
 
getPermission(String, List<String>) - Method in interface alluxio.master.file.meta.InodeView
Gets the permitted actions for a user.
getPermission(String, List<String>) - Method in class alluxio.master.file.meta.MutableInode
 
getPermission(LockedInodePath) - Method in interface alluxio.master.file.PermissionChecker
Gets the permission to access inodePath for the current client user.
getPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
getPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 permission = 8;
getPermission() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 permission = 8;
getPermission(String, List<String>) - Method in class alluxio.security.authorization.AccessControlList
Gets the permitted actions for a user.
getPermissionError() - Method in class alluxio.wire.MasterWebUIData
Gets permission error.
getPermissions() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.ObjectUnderFileSystem
Permissions for the mounted bucket.
getPermissions() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getPermissions() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getPersist() - Method in class alluxio.grpc.RenamePOptions.Builder
optional bool persist = 2;
getPersist() - Method in class alluxio.grpc.RenamePOptions
optional bool persist = 2;
getPersist() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional bool persist = 2;
getPersist() - Method in class alluxio.master.file.contexts.RenameContext
 
getPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersistDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
getPersisted() - Method in class alluxio.grpc.FileInfo.Builder
optional bool persisted = 12;
getPersisted() - Method in class alluxio.grpc.FileInfo
optional bool persisted = 12;
getPersisted() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool persisted = 12;
getPersisted() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool persisted = 2;
getPersisted() - Method in class alluxio.grpc.SetAttributePOptions
optional bool persisted = 2;
getPersisted() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool persisted = 2;
getPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
getPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool persisted = 5;
getPersisted() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool persisted = 5;
getPersistedFileFingerprints(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprints(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprints(int) - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsBytes(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsBytes(int) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsBytes(int) - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsCount() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsCount() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsCount() - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsList() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsList() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
repeated string persistedFileFingerprints = 1;
getPersistedFileFingerprintsList() - Method in interface alluxio.grpc.FileSystemHeartbeatPOptionsOrBuilder
repeated string persistedFileFingerprints = 1;
getPersistedFiles(int) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the list of persisted files
getPersistedFiles(int) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
the list of persisted files
getPersistedFiles(int) - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
the list of persisted files
getPersistedFilesCount() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the list of persisted files
getPersistedFilesCount() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
the list of persisted files
getPersistedFilesCount() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
the list of persisted files
getPersistedFilesList() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the list of persisted files
getPersistedFilesList() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
the list of persisted files
getPersistedFilesList() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
the list of persisted files
getPersistenceState() - Method in class alluxio.client.file.URIStatus
 
getPersistenceState() - Method in class alluxio.grpc.FileInfo.Builder
optional string persistenceState = 19;
getPersistenceState() - Method in class alluxio.grpc.FileInfo
optional string persistenceState = 19;
getPersistenceState() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string persistenceState = 19;
getPersistenceState(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getPersistenceState(long) - Method in interface alluxio.master.file.FileSystemMaster
Returns the persistence state for a file id.
getPersistenceState() - Method in class alluxio.master.file.meta.Inode
 
getPersistenceState() - Method in interface alluxio.master.file.meta.InodeView
 
getPersistenceState() - Method in class alluxio.master.file.meta.MutableInode
 
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string persistence_state = 4;
getPersistenceState() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string persistence_state = 4;
getPersistenceState() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string persistence_state = 4;
getPersistenceState() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string persistence_state = 4;
getPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persistence_state = 8;
getPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string persistence_state = 8;
getPersistenceState() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string persistence_state = 8;
getPersistenceState() - Method in class alluxio.util.webui.UIFileInfo
Gets persistence state.
getPersistenceState() - Method in class alluxio.wire.FileInfo
 
getPersistenceStateBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string persistenceState = 19;
getPersistenceStateBytes() - Method in class alluxio.grpc.FileInfo
optional string persistenceState = 19;
getPersistenceStateBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string persistenceState = 19;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string persistence_state = 4;
getPersistenceStateBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persistence_state = 8;
getPersistenceStateBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string persistence_state = 8;
getPersistenceStateBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string persistence_state = 8;
getPersistenceWaitTime() - Method in class alluxio.client.file.options.OutStreamOptions
 
getPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 persistenceWaitTime = 10;
getPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions
optional int64 persistenceWaitTime = 10;
getPersistenceWaitTime() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int64 persistenceWaitTime = 10;
getPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional int64 persistenceWaitTime = 2;
getPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
optional int64 persistenceWaitTime = 2;
getPersistenceWaitTime() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
optional int64 persistenceWaitTime = 2;
getPersistenceWaitTime() - Method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
 
getPersistentTmpPath(AlluxioConfiguration, String) - Static method in class alluxio.util.io.PathUtils
Get temp path for async persistence job.
getPersistFiles(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFiles(int) - Method in class alluxio.grpc.PersistCommandOptions
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFiles(int) - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesBuilderList() - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesCount() - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesCount() - Method in class alluxio.grpc.PersistCommandOptions
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesCount() - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesList() - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesList() - Method in class alluxio.grpc.PersistCommandOptions
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesList() - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesOrBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesOrBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesOrBuilder(int) - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesOrBuilderList() - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesOrBuilderList() - Method in class alluxio.grpc.PersistCommandOptions
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistFilesOrBuilderList() - Method in interface alluxio.grpc.PersistCommandOptionsOrBuilder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
getPersistJobId() - Method in class alluxio.master.file.meta.InodeFile
 
getPersistJobId() - Method in interface alluxio.master.file.meta.InodeFileView
 
getPersistJobId() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 persist_job_id = 22;
getPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 persist_job_id = 22;
getPersistJobId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 persist_job_id = 22;
getPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 persistJobId = 11;
getPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 persistJobId = 11;
getPersistJobId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 persistJobId = 11;
getPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 persist_job_id = 10;
getPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 persist_job_id = 10;
getPersistJobId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 persist_job_id = 10;
getPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Used for recovering in-progress file persist jobs on master start.
getPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode
Used for recovering in-progress file persist jobs on master start.
getPersistJobId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Used for recovering in-progress file persist jobs on master start.
getPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persist_job_temp_ufs_path = 24;
getPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string persist_job_temp_ufs_path = 24;
getPersistJobTempUfsPath() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string persist_job_temp_ufs_path = 24;
getPersistJobTempUfsPathBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persist_job_temp_ufs_path = 24;
getPersistJobTempUfsPathBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string persist_job_temp_ufs_path = 24;
getPersistJobTempUfsPathBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string persist_job_temp_ufs_path = 24;
getPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
getPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
getPersistOptions() - Method in interface alluxio.grpc.FileSystemCommandOptionsOrBuilder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
getPersistOptions() - Method in class alluxio.wire.FileSystemCommandOptions
 
getPersistOptionsBuilder() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
getPersistOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
getPersistOptionsOrBuilder() - Method in class alluxio.grpc.FileSystemCommandOptions
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
getPersistOptionsOrBuilder() - Method in interface alluxio.grpc.FileSystemCommandOptionsOrBuilder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
getPhysicalStores() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getPhysicalStores() - Method in class alluxio.underfs.BaseUnderFileSystem
 
getPhysicalStores() - Method in interface alluxio.underfs.UnderFileSystem
An UnderFileSystem may be composed of one or more "physical UFS"s.
getPhysicalStores() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getPhysicalUfsState(List<String>) - Method in class alluxio.underfs.MasterUfsManager
Get the physical ufs operation modes for the UnderFileSystem under the given Mount table resolution.
getPinIdList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getPinIdList() - Method in interface alluxio.master.file.FileSystemMaster
 
getPinIdSet() - Method in class alluxio.master.file.meta.InodeTree
 
getPinList() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getPinned() - Method in class alluxio.grpc.FileInfo.Builder
optional bool pinned = 10;
getPinned() - Method in class alluxio.grpc.FileInfo
optional bool pinned = 10;
getPinned() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool pinned = 10;
getPinned() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool pinned = 1;
getPinned() - Method in class alluxio.grpc.SetAttributePOptions
optional bool pinned = 1;
getPinned() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool pinned = 1;
getPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool pinned = 5;
getPinned() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool pinned = 5;
getPinned() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool pinned = 3;
getPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool pinned = 3;
getPinned() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool pinned = 3;
getPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool pinned = 5;
getPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional bool pinned = 5;
getPinned() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional bool pinned = 5;
getPinnedFileIds(GetPinnedFileIdsPRequest, StreamObserver<GetPinnedFileIdsPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
Returns the set of pinned file ids.
getPinnedFileIds(GetPinnedFileIdsPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
Returns the set of pinned file ids.
getPinnedFileIds(GetPinnedFileIdsPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
Returns the set of pinned file ids.
getPinnedFileIds(GetPinnedFileIdsPRequest, StreamObserver<GetPinnedFileIdsPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
Returns the set of pinned file ids.
getPinnedFileIds(int) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
TODO(adit): set replacement?
getPinnedFileIds(int) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
TODO(adit): set replacement?
getPinnedFileIds(int) - Method in interface alluxio.grpc.GetPinnedFileIdsPResponseOrBuilder
TODO(adit): set replacement?
getPinnedFileIds(GetPinnedFileIdsPRequest, StreamObserver<GetPinnedFileIdsPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getPinnedFileIdsCount() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
TODO(adit): set replacement?
getPinnedFileIdsCount() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
TODO(adit): set replacement?
getPinnedFileIdsCount() - Method in interface alluxio.grpc.GetPinnedFileIdsPResponseOrBuilder
TODO(adit): set replacement?
getPinnedFileIdsList() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
TODO(adit): set replacement?
getPinnedFileIdsList() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
TODO(adit): set replacement?
getPinnedFileIdsList() - Method in interface alluxio.grpc.GetPinnedFileIdsPResponseOrBuilder
TODO(adit): set replacement?
GetPinnedFileIdsPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPOptions
GetPinnedFileIdsPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPOptions
GetPinnedFileIdsPOptionsOrBuilder - Interface in alluxio.grpc
 
GetPinnedFileIdsPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPRequest
GetPinnedFileIdsPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPRequest
GetPinnedFileIdsPRequestOrBuilder - Interface in alluxio.grpc
 
GetPinnedFileIdsPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPResponse
GetPinnedFileIdsPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetPinnedFileIdsPResponse
GetPinnedFileIdsPResponseOrBuilder - Interface in alluxio.grpc
 
getPinnedInodeFileIds() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getPinnedMedia(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
getPinnedMedia(int) - Method in class alluxio.grpc.SetAttributePOptions
repeated string pinnedMedia = 10;
getPinnedMedia(int) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
repeated string pinnedMedia = 10;
getPinnedMediaBytes(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
getPinnedMediaBytes(int) - Method in class alluxio.grpc.SetAttributePOptions
repeated string pinnedMedia = 10;
getPinnedMediaBytes(int) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
repeated string pinnedMedia = 10;
getPinnedMediaCount() - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
getPinnedMediaCount() - Method in class alluxio.grpc.SetAttributePOptions
repeated string pinnedMedia = 10;
getPinnedMediaCount() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
repeated string pinnedMedia = 10;
getPinnedMediaList() - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
getPinnedMediaList() - Method in class alluxio.grpc.SetAttributePOptions
repeated string pinnedMedia = 10;
getPinnedMediaList() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
repeated string pinnedMedia = 10;
getPinnedMediumTypes() - Method in class alluxio.client.file.URIStatus
 
getPinnedSize() - Method in class alluxio.master.file.meta.InodeTree
 
getPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool pin_on_create = 9;
getPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand
optional bool pin_on_create = 9;
getPinOnCreate() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional bool pin_on_create = 9;
getPlanInfo() - Method in class alluxio.master.job.plan.PlanCoordinator
 
getPlanInfoWire(boolean) - Method in class alluxio.master.job.plan.PlanCoordinator
 
getPluginMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry name for plugin instance.
getPoints() - Method in class alluxio.stress.worker.IOTaskResult
 
getPoints() - Method in class alluxio.stress.worker.IOTaskSummary
 
getPolicy() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicy() - Method in class alluxio.grpc.AddPolicyPResponse
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicy() - Method in interface alluxio.grpc.AddPolicyPResponseOrBuilder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicy(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicy(int) - Method in class alluxio.grpc.ListPolicyPResponse
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicy(int) - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyBuilder() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyBuilder(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyBuilderList() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyCount() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyCount() - Method in class alluxio.grpc.ListPolicyPResponse
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyCount() - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
getPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
getPolicyDefinition() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
getPolicyDefinitionBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
getPolicyDefinitionOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
getPolicyDefinitionOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
getPolicyDefinitionOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
getPolicyList() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyList() - Method in class alluxio.grpc.ListPolicyPResponse
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyList() - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest
optional string policyName = 1;
getPolicyName() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest
optional string policyName = 1;
getPolicyName() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest
optional string policyName = 1;
getPolicyName() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest
optional string policyName = 1;
getPolicyName() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
optional string policyName = 1;
getPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest
optional string policyName = 1;
getPolicyName() - Method in interface alluxio.grpc.TriggerPolicyRequestOrBuilder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.AddPolicyPRequest
optional string policyName = 1;
getPolicyNameBytes() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.GetActionInfoRequest
optional string policyName = 1;
getPolicyNameBytes() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.GetPolicyStatusPRequest
optional string policyName = 1;
getPolicyNameBytes() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.RemovePolicyPRequest
optional string policyName = 1;
getPolicyNameBytes() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
optional string policyName = 1;
getPolicyNameBytes() - Method in class alluxio.grpc.TriggerPolicyRequest
optional string policyName = 1;
getPolicyNameBytes() - Method in interface alluxio.grpc.TriggerPolicyRequestOrBuilder
optional string policyName = 1;
getPolicyOrBuilder() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilder() - Method in class alluxio.grpc.AddPolicyPResponse
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilder() - Method in interface alluxio.grpc.AddPolicyPResponseOrBuilder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilder(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilder(int) - Method in class alluxio.grpc.ListPolicyPResponse
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilder(int) - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilderList() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilderList() - Method in class alluxio.grpc.ListPolicyPResponse
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyOrBuilderList() - Method in interface alluxio.grpc.ListPolicyPResponseOrBuilder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
getPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
getPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
getPolicyRemove() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
getPolicyRemoveBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
getPolicyRemoveOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
getPolicyRemoveOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
getPolicyRemoveOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
getPolicyStatus(GetPolicyStatusPRequest, StreamObserver<GetPolicyStatusPResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
Gets the status of a policy
getPolicyStatus(GetPolicyStatusPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
Gets the status of a policy
getPolicyStatus(GetPolicyStatusPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
Gets the status of a policy
getPolicyStatus(GetPolicyStatusPRequest, StreamObserver<GetPolicyStatusPResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
Gets the status of a policy
GetPolicyStatusPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetPolicyStatusPOptions
GetPolicyStatusPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetPolicyStatusPOptions
GetPolicyStatusPOptionsOrBuilder - Interface in alluxio.grpc
 
GetPolicyStatusPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetPolicyStatusPRequest
GetPolicyStatusPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetPolicyStatusPRequest
GetPolicyStatusPRequestOrBuilder - Interface in alluxio.grpc
 
GetPolicyStatusPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetPolicyStatusPResponse
GetPolicyStatusPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.GetPolicyStatusPResponse
GetPolicyStatusPResponseOrBuilder - Interface in alluxio.grpc
 
getPool() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the pool hosting the current thread, or null if the current thread is executing outside of any ForkJoinPool.
getPool() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPoolIndex() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Returns the unique index number of this thread in its pool.
getPoolSize() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getPoolSize() - Method in class alluxio.master.AlluxioExecutorService
 
getPort() - Method in class alluxio.cli.LogLevel.TargetInfo
 
getPort() - Method in class alluxio.master.CoreMasterContext
 
getPort() - Method in class alluxio.multi.process.PortCoordination.ReservedPort
 
getPort() - Method in class alluxio.uri.SingleMasterAuthority
 
getPort(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the port number on a given service type.
getPort() - Method in class alluxio.worker.http.HttpRequestUri
Get the port of the request URI.
getPortKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the key of service port.
getPortKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of service port.
getPos() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
getPos() - Method in class alluxio.client.file.PositionReadFileInStream
 
getPos() - Method in class alluxio.client.file.ufs.UfsFileInStream
 
getPos() - Method in class alluxio.file.SeekableBufferedInputStream
 
getPos() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
getPos() - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
getPos() - Method in interface alluxio.Positioned
 
getPos() - Method in class alluxio.underfs.cephfs.CephInputStream
Gets the current position of the stream.
getPos() - Method in class alluxio.underfs.cephfs.CephSeekableInputStream
 
getPos() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
getPos() - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
 
getPos() - Method in class alluxio.underfs.s3a.S3AInputStream
 
getPos() - Method in class alluxio.worker.dora.OpenFileHandle
Get write position of the out stream in this handle.
getPos() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getPosition() - Method in class alluxio.worker.block.io.BlockWriter
 
getPosition() - Method in class alluxio.worker.dora.PagedFileWriter
 
getPositionShort() - Method in class alluxio.client.file.options.InStreamOptions
 
getPositionShort() - Method in class alluxio.grpc.ReadRequest.Builder
Is position read to a small buffer
getPositionShort() - Method in class alluxio.grpc.ReadRequest
Is position read to a small buffer
getPositionShort() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Is position read to a small buffer
getPositionShort() - Method in class alluxio.grpc.UfsReadOptions.Builder
is position short or not, used for HDFS performance optimization.
getPositionShort() - Method in class alluxio.grpc.UfsReadOptions
is position short or not, used for HDFS performance optimization.
getPositionShort() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
is position short or not, used for HDFS performance optimization.
getPositionShort() - Method in class alluxio.underfs.options.OpenOptions
 
getPosReceived() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getPossibleMountPoints(String) - Static method in class alluxio.util.io.PathUtils
Returns the list of possible mount points of the given path.
getPosToQueue() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getPosToQueue() - Method in class alluxio.worker.netty.ReadRequestContext
 
getPosToQueue() - Method in class alluxio.worker.netty.WriteRequestContext
 
getPosToWrite() - Method in class alluxio.worker.netty.ReadRequestContext
 
getPosToWrite() - Method in class alluxio.worker.netty.WriteRequestContext
 
getPreferredWorker() - Method in class alluxio.cli.fs.command.FileLocation
Get the preferred worker.
getPreferredWorkers(List<BlockWorkerInfo>, String, int) - Method in class alluxio.client.file.dora.ConsistentHashPolicy
 
getPreferredWorkers(List<BlockWorkerInfo>, String, int) - Method in class alluxio.client.file.dora.LocalWorkerPolicy
Finds a local worker from the available workers, matching by hostname.
getPreferredWorkers(List<BlockWorkerInfo>, String, int) - Method in interface alluxio.client.file.dora.WorkerLocationPolicy
Find a specified number of workers following the logic defined by the policy.
getPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only match files with a given prefix.
getPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions
Only match files with a given prefix.
getPrefix() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Only match files with a given prefix.
getPrefix() - Method in class alluxio.master.metastore.ReadOption
 
getPrefix() - Method in class alluxio.s3.ListBucketOptions
 
getPrefix() - Method in class alluxio.s3.ListBucketResult.CommonPrefix
 
getPrefix() - Method in class alluxio.s3.ListBucketResult
 
getPrefixBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only match files with a given prefix.
getPrefixBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions
Only match files with a given prefix.
getPrefixBytes() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Only match files with a given prefix.
getPreviousVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 previous_version = 9;
getPreviousVersion() - Method in class alluxio.grpc.table.TableInfo
optional int64 previous_version = 9;
getPreviousVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional int64 previous_version = 9;
getPrimaryGroupName(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
Gets the primary group name of a user.
getPrimaryMasterAddress() - Method in class alluxio.client.block.AllMastersWorkerInfo
 
getPrimaryMasterAddressCached(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
getPrimaryMasterAddressCached(MasterInquireClient) - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
Get and cache the primary master address.
getPrimaryMasterIndex(int) - Method in class alluxio.multi.process.MultiProcessCluster
Gets the index of the primary master.
getPrimaryMasterInfo() - Method in class alluxio.wire.MasterWebUIMasters
Get info of the primary master.
getPrimaryMasterWorkerInfo() - Method in class alluxio.client.block.AllMastersWorkerInfo
 
getPrimaryRpcAddress() - Method in interface alluxio.master.MasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.PollingMasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.SingleMasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.ZkMasterInquireClient
 
getPrimarySelector() - Method in class alluxio.master.CoreMasterContext
 
getPrimarySelector() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
getPrimarySelector() - Method in class alluxio.master.MasterContext
 
getPrimarySelector() - Method in class alluxio.master.MasterProcess
 
getPrintStream() - Method in class alluxio.cli.fsadmin.command.Context
 
getPriority() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional int32 priority = 4;
getPriority() - Method in class alluxio.grpc.QuorumServerInfo
optional int32 priority = 4;
getPriority() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional int32 priority = 4;
getPriority() - Method in class alluxio.scheduler.job.Task
 
getProcessLocalWorker() - Method in class alluxio.client.file.FileSystemContext
Acquires the internal block worker as a gateway for worker internal clients to communicate with the local worker directly without going through external RPC frameworks.
getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.CopyJob
 
getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.DoraLoadJob
 
getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.LoadJob
 
getProgress(JobProgressReportFormat, boolean) - Method in class alluxio.master.job.MoveJob
 
getProgress(JobProgressReportFormat, boolean) - Method in interface alluxio.scheduler.job.Job
Get job progress.
getProgressPercentage() - Method in class alluxio.grpc.CmdSummary.Builder
optional float progressPercentage = 9;
getProgressPercentage() - Method in class alluxio.grpc.CmdSummary
optional float progressPercentage = 9;
getProgressPercentage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional float progressPercentage = 9;
getProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional string progressReport = 1;
getProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse
optional string progressReport = 1;
getProgressReport() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
optional string progressReport = 1;
getProgressReportBytes() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional string progressReport = 1;
getProgressReportBytes() - Method in class alluxio.grpc.GetJobProgressPResponse
optional string progressReport = 1;
getProgressReportBytes() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
optional string progressReport = 1;
getPromote() - Method in class alluxio.grpc.ReadRequest.Builder
Whether the block should be promoted before reading
getPromote() - Method in class alluxio.grpc.ReadRequest
Whether the block should be promoted before reading
getPromote() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Whether the block should be promoted before reading
getPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
getPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional bool promote = 2;
getPromote() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional bool promote = 2;
getPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
Whether the block should be promoted before reading
getPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
Whether the block should be promoted before reading
getPromote() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
Whether the block should be promoted before reading
getProperties() - Method in class alluxio.conf.InstancedConfiguration
Return reference to mProperties.
getProperties() - Method in class alluxio.conf.reference.DemoProperty
 
getProperties() - Method in interface alluxio.conf.reference.ReferenceProperty
Get the reference properties.
getProperties(int) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getProperties(int) - Method in class alluxio.grpc.ConfigProperties
repeated .alluxio.grpc.ConfigProperty properties = 1;
getProperties(int) - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getProperties(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getProperties(int) - Method in class alluxio.grpc.InconsistentProperties
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getProperties(int) - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getProperties() - Method in class alluxio.grpc.MountPointInfo.Builder
Deprecated.
getProperties() - Method in class alluxio.grpc.MountPointInfo
Deprecated.
getProperties() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
Deprecated.
getProperties() - Method in class alluxio.grpc.MountPOptions.Builder
Deprecated.
getProperties() - Method in class alluxio.grpc.MountPOptions
Deprecated.
getProperties() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
Deprecated.
getProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
Deprecated.
getProperties() - Method in class alluxio.grpc.SetPathConfigurationPRequest
Deprecated.
getProperties() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
Deprecated.
getProperties() - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
getProperties() - Method in class alluxio.grpc.UfsInfo
optional .alluxio.grpc.file.MountPOptions properties = 2;
getProperties() - Method in interface alluxio.grpc.UfsInfoOrBuilder
optional .alluxio.grpc.file.MountPOptions properties = 2;
getProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
Deprecated.
getProperties() - Method in class alluxio.grpc.UpdateConfigurationPRequest
Deprecated.
getProperties() - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
Deprecated.
getProperties() - Method in class alluxio.master.meta.PathProperties.State
 
getProperties(String) - Method in class alluxio.master.meta.PathProperties.State
 
getProperties() - Method in class alluxio.master.meta.PathPropertiesView
 
getProperties() - Method in class alluxio.metrics.MetricsConfig
 
getProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getProperties(int) - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
Deprecated.
getProperties() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
Deprecated.
getProperties() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
Deprecated.
getProperties() - Method in class alluxio.util.webui.UIMountPointInfo
 
getProperties() - Method in class alluxio.wire.MountPointInfo
 
getPropertiesBuilder(int) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesBuilder(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesBuilder() - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
getPropertiesBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesBuilderList() - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesBuilderList() - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesCount() - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesCount() - Method in class alluxio.grpc.ConfigProperties
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesCount() - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesCount() - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesCount() - Method in class alluxio.grpc.InconsistentProperties
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesCount() - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesCount() - Method in class alluxio.grpc.MountPointInfo.Builder
 
getPropertiesCount() - Method in class alluxio.grpc.MountPointInfo
 
getPropertiesCount() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
map<string, string> properties = 6;
getPropertiesCount() - Method in class alluxio.grpc.MountPOptions.Builder
 
getPropertiesCount() - Method in class alluxio.grpc.MountPOptions
 
getPropertiesCount() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
map<string, string> properties = 2;
getPropertiesCount() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
getPropertiesCount() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
getPropertiesCount() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
map<string, string> properties = 2;
getPropertiesCount() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
getPropertiesCount() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
getPropertiesCount() - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
map<string, string> properties = 1;
getPropertiesCount() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesCount() - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesCount() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesCount() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
getPropertiesCount() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
getPropertiesCount() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
map<string, string> properties = 2;
getPropertiesList() - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesList() - Method in class alluxio.grpc.ConfigProperties
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesList() - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesList() - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesList() - Method in class alluxio.grpc.InconsistentProperties
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesList() - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesList() - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesList() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesMap() - Method in class alluxio.grpc.MountPointInfo.Builder
map<string, string> properties = 6;
getPropertiesMap() - Method in class alluxio.grpc.MountPointInfo
map<string, string> properties = 6;
getPropertiesMap() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
map<string, string> properties = 6;
getPropertiesMap() - Method in class alluxio.grpc.MountPOptions.Builder
map<string, string> properties = 2;
getPropertiesMap() - Method in class alluxio.grpc.MountPOptions
map<string, string> properties = 2;
getPropertiesMap() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
map<string, string> properties = 2;
getPropertiesMap() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
map<string, string> properties = 2;
getPropertiesMap() - Method in class alluxio.grpc.SetPathConfigurationPRequest
map<string, string> properties = 2;
getPropertiesMap() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
map<string, string> properties = 2;
getPropertiesMap() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
map<string, string> properties = 1;
getPropertiesMap() - Method in class alluxio.grpc.UpdateConfigurationPRequest
map<string, string> properties = 1;
getPropertiesMap() - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
map<string, string> properties = 1;
getPropertiesMap() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
map<string, string> properties = 2;
getPropertiesMap() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
map<string, string> properties = 2;
getPropertiesMap() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
map<string, string> properties = 2;
getPropertiesOrBuilder(int) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesOrBuilder(int) - Method in class alluxio.grpc.ConfigProperties
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesOrBuilder(int) - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesOrBuilder(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesOrBuilder(int) - Method in class alluxio.grpc.InconsistentProperties
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesOrBuilder(int) - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesOrBuilder() - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
getPropertiesOrBuilder() - Method in class alluxio.grpc.UfsInfo
optional .alluxio.grpc.file.MountPOptions properties = 2;
getPropertiesOrBuilder() - Method in interface alluxio.grpc.UfsInfoOrBuilder
optional .alluxio.grpc.file.MountPOptions properties = 2;
getPropertiesOrBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilder(int) - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilderList() - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesOrBuilderList() - Method in class alluxio.grpc.ConfigProperties
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesOrBuilderList() - Method in interface alluxio.grpc.ConfigPropertiesOrBuilder
repeated .alluxio.grpc.ConfigProperty properties = 1;
getPropertiesOrBuilderList() - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesOrBuilderList() - Method in class alluxio.grpc.InconsistentProperties
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesOrBuilderList() - Method in interface alluxio.grpc.InconsistentPropertiesOrBuilder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
getPropertiesOrBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilderList() - Method in class alluxio.proto.journal.File.AddMountPointEntry
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrBuilderList() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPointInfo.Builder
map<string, string> properties = 6;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPointInfo
map<string, string> properties = 6;
getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.MountPointInfoOrBuilder
map<string, string> properties = 6;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPOptions.Builder
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.MountPOptions
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.MountPOptionsOrBuilder
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.SetPathConfigurationPRequest
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
map<string, string> properties = 1;
getPropertiesOrDefault(String, String) - Method in class alluxio.grpc.UpdateConfigurationPRequest
map<string, string> properties = 1;
getPropertiesOrDefault(String, String) - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
map<string, string> properties = 1;
getPropertiesOrDefault(String, String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
map<string, string> properties = 2;
getPropertiesOrDefault(String, String) - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPointInfo.Builder
map<string, string> properties = 6;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPointInfo
map<string, string> properties = 6;
getPropertiesOrThrow(String) - Method in interface alluxio.grpc.MountPointInfoOrBuilder
map<string, string> properties = 6;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPOptions.Builder
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.MountPOptions
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in interface alluxio.grpc.MountPOptionsOrBuilder
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
map<string, string> properties = 1;
getPropertiesOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest
map<string, string> properties = 1;
getPropertiesOrThrow(String) - Method in interface alluxio.grpc.UpdateConfigurationPRequestOrBuilder
map<string, string> properties = 1;
getPropertiesOrThrow(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
map<string, string> properties = 2;
getPropertiesOrThrow(String) - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
map<string, string> properties = 2;
getPropertyCode() - Method in enum alluxio.grpc.GrpcNetworkGroup
 
getProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
getProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional .alluxio.grpc.NetAddress proxyAddress = 1;
getProxyAddress() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
getProxyAddressBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
getProxyAddressOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
getProxyAddressOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional .alluxio.grpc.NetAddress proxyAddress = 1;
getProxyAddressOrBuilder() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
getProxyDownloadFileApiUrl() - Method in class alluxio.wire.MasterWebUIInit
Gets proxy download file api url.
getProxyFor(InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingProxy
 
getProxyHeartbeatMethod() - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
 
getProxyProcess() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Gets the proxy process.
getProxyStatuses(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatuses(int) - Method in class alluxio.grpc.ListProxyStatusPResponse
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatuses(int) - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesBuilder(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesBuilderList() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesCount() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesCount() - Method in class alluxio.grpc.ListProxyStatusPResponse
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesCount() - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesList() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesList() - Method in class alluxio.grpc.ListProxyStatusPResponse
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesList() - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesOrBuilder(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesOrBuilder(int) - Method in class alluxio.grpc.ListProxyStatusPResponse
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesOrBuilder(int) - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesOrBuilderList() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesOrBuilderList() - Method in class alluxio.grpc.ListProxyStatusPResponse
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getProxyStatusesOrBuilderList() - Method in interface alluxio.grpc.ListProxyStatusPResponseOrBuilder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
getQuery() - Method in class alluxio.uri.StandardURI
 
getQuery() - Method in interface alluxio.uri.URI
 
getQueryMap() - Method in class alluxio.AlluxioURI
Gets the map of query parameters.
getQueryParameter(String) - Method in class alluxio.proxy.s3.S3Handler
retrieve given query parameter value.
getQueryParameter(String) - Method in class alluxio.worker.s3.S3NettyHandler
retrieve given query parameter value.
getQueuedSubmissionCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
getQueuedTaskCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the total number of tasks currently held in queues by worker threads (but not including tasks submitted to the pool that have not begun executing).
getQueuedTaskCount() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.
getQuiet() - Method in class alluxio.s3.DeleteObjectsRequest
 
getQuietPeriodMs() - Method in class alluxio.master.journal.ufs.UfsJournal
 
getQuorumInfo() - Method in interface alluxio.client.journal.JournalMasterClient
Quorum information for participating servers in journal.
getQuorumInfo() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
getQuorumInfo(GetQuorumInfoPRequest, StreamObserver<GetQuorumInfoPResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
Gets list of server states in an embedded journal quorum.
getQuorumInfo(GetQuorumInfoPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
Gets list of server states in an embedded journal quorum.
getQuorumInfo(GetQuorumInfoPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
Gets list of server states in an embedded journal quorum.
getQuorumInfo(GetQuorumInfoPRequest, StreamObserver<GetQuorumInfoPResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
Gets list of server states in an embedded journal quorum.
getQuorumInfo() - Method in class alluxio.master.journal.DefaultJournalMaster
 
getQuorumInfo() - Method in interface alluxio.master.journal.JournalMaster
Quorum information for participating servers in journal.
getQuorumInfo(GetQuorumInfoPRequest, StreamObserver<GetQuorumInfoPResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
 
GetQuorumInfoPOptions - Class in alluxio.grpc
GetQuorumInfo API
GetQuorumInfoPOptions.Builder - Class in alluxio.grpc
GetQuorumInfo API
GetQuorumInfoPOptionsOrBuilder - Interface in alluxio.grpc
 
GetQuorumInfoPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetQuorumInfoPRequest
GetQuorumInfoPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetQuorumInfoPRequest
GetQuorumInfoPRequestOrBuilder - Interface in alluxio.grpc
 
GetQuorumInfoPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetQuorumInfoPResponse
GetQuorumInfoPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetQuorumInfoPResponse
GetQuorumInfoPResponseOrBuilder - Interface in alluxio.grpc
 
getQuorumServerInfoList() - Method in class alluxio.master.journal.raft.RaftJournalSystem
Used to get information of internal RAFT quorum.
getQuota(CacheScope) - Method in class alluxio.client.quota.CacheQuota
 
getRaftAddress(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
getRaftAddress(int) - Method in class alluxio.grpc.MasterInfo
repeated string raftAddress = 13;
getRaftAddress(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated string raftAddress = 13;
getRaftAddressBytes(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
getRaftAddressBytes(int) - Method in class alluxio.grpc.MasterInfo
repeated string raftAddress = 13;
getRaftAddressBytes(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated string raftAddress = 13;
getRaftAddressCount() - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
getRaftAddressCount() - Method in class alluxio.grpc.MasterInfo
repeated string raftAddress = 13;
getRaftAddressCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated string raftAddress = 13;
getRaftAddressList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
getRaftAddressList() - Method in class alluxio.grpc.MasterInfo
repeated string raftAddress = 13;
getRaftAddressList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated string raftAddress = 13;
getRaftJournal() - Method in class alluxio.grpc.MasterInfo.Builder
optional bool raftJournal = 12;
getRaftJournal() - Method in class alluxio.grpc.MasterInfo
optional bool raftJournal = 12;
getRaftJournal() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional bool raftJournal = 12;
getRaftJournalAddress() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get raft journal address.
getRaftJournalDir(File) - Static method in class alluxio.master.journal.raft.RaftJournalUtils
Gets the raft journal dir.
getRandomNonNegativeLong() - Static method in class alluxio.util.IdUtils
Generates a positive random number by zero-ing the sign bit.
getRange() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
getRange() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.RangeSet range = 1;
getRange() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.RangeSet range = 1;
getRangeBuilder() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
getRangeOrBuilder() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
getRangeOrBuilder() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.RangeSet range = 1;
getRangeOrBuilder() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.RangeSet range = 1;
getRanges(int) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
getRanges(int) - Method in class alluxio.grpc.table.RangeSet
repeated .alluxio.grpc.table.Range ranges = 1;
getRanges(int) - Method in interface alluxio.grpc.table.RangeSetOrBuilder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesBuilder(int) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesBuilderList() - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesCount() - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesCount() - Method in class alluxio.grpc.table.RangeSet
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesCount() - Method in interface alluxio.grpc.table.RangeSetOrBuilder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesList() - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesList() - Method in class alluxio.grpc.table.RangeSet
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesList() - Method in interface alluxio.grpc.table.RangeSetOrBuilder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesOrBuilder(int) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesOrBuilder(int) - Method in class alluxio.grpc.table.RangeSet
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesOrBuilder(int) - Method in interface alluxio.grpc.table.RangeSetOrBuilder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesOrBuilderList() - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesOrBuilderList() - Method in class alluxio.grpc.table.RangeSet
repeated .alluxio.grpc.table.Range ranges = 1;
getRangesOrBuilderList() - Method in interface alluxio.grpc.table.RangeSetOrBuilder
repeated .alluxio.grpc.table.Range ranges = 1;
getRawReadWriteLock(K) - Method in class alluxio.collections.LockPool
Get the raw readwrite lock from the pool.
getRawResult() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the result of the computation.
getRawResult() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the result that would be returned by ForkJoinTask.join(), even if this task completed abnormally, or null if this task is not known to have been completed.
getRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool rawValue = 1;
getRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions
optional bool rawValue = 1;
getRawValue() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
optional bool rawValue = 1;
getReadBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getReader(boolean) - Method in class alluxio.master.journal.ufs.UfsJournal
 
getReader() - Method in interface alluxio.master.journalv0.Journal
 
getReader() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
getReadOnly() - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool readOnly = 5;
getReadOnly() - Method in class alluxio.grpc.MountPointInfo
optional bool readOnly = 5;
getReadOnly() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional bool readOnly = 5;
getReadOnly() - Method in class alluxio.grpc.MountPOptions.Builder
optional bool readOnly = 1;
getReadOnly() - Method in class alluxio.grpc.MountPOptions
optional bool readOnly = 1;
getReadOnly() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
optional bool readOnly = 1;
getReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
getReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool readOnly = 3;
getReadOnly() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool readOnly = 3;
getReadOnly() - Method in class alluxio.wire.MountPointInfo
 
getReadOnlyByteBuffer() - Method in class alluxio.grpc.ReadableDataBuffer
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
getReadOnlyByteBuffer() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns a ByteBuffer for read-only access to the data.
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
getReadSpeedStat() - Method in class alluxio.stress.worker.IOTaskSummary
 
getReadTableMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getReadType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.ReadPType readType = 1;
getReadType() - Method in class alluxio.grpc.OpenFilePOptions
optional .alluxio.grpc.file.ReadPType readType = 1;
getReadType() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional .alluxio.grpc.file.ReadPType readType = 1;
getRealRange(long) - Method in class alluxio.s3.S3RangeSpec
Get real range of response.
getRecentActivities(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivities(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivities(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivities() - Method in class alluxio.job.wire.JobServiceSummary
 
getRecentActivitiesBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesCount() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentActivitiesOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
getRecentFailedJobs() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Get recent failed jobs.
getRecentFailures(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailures(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailures(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailures() - Method in class alluxio.job.wire.JobServiceSummary
 
getRecentFailuresBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresCount() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentFailuresOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
getRecentModifiedJobs() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Get recent modified jobs.
getRecorder() - Method in class alluxio.master.file.contexts.MountContext
Gets the Recorder.
getRecordStartMs() - Method in class alluxio.stress.client.ClientIOTaskResult
 
getRecordStartMs() - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
getRecordStartMs() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getRecoverFailedOpen() - Method in class alluxio.underfs.options.OpenOptions
 
getRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool recursive = 1;
getRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional bool recursive = 1;
getRecursive() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional bool recursive = 1;
getRecursive() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool recursive = 2;
getRecursive() - Method in class alluxio.grpc.CreateFilePOptions
optional bool recursive = 2;
getRecursive() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool recursive = 2;
getRecursive() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool recursive = 1;
getRecursive() - Method in class alluxio.grpc.DeletePOptions
optional bool recursive = 1;
getRecursive() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool recursive = 1;
getRecursive() - Method in class alluxio.grpc.FreePOptions.Builder
optional bool recursive = 1;
getRecursive() - Method in class alluxio.grpc.FreePOptions
optional bool recursive = 1;
getRecursive() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
optional bool recursive = 1;
getRecursive() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional bool recursive = 4;
getRecursive() - Method in class alluxio.grpc.ListStatusPOptions
optional bool recursive = 4;
getRecursive() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
optional bool recursive = 4;
getRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
whether to load metadata recursively
getRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions
whether to load metadata recursively
getRecursive() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
whether to load metadata recursively
getRecursive() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional bool recursive = 2;
getRecursive() - Method in class alluxio.grpc.SetAclPOptions
optional bool recursive = 2;
getRecursive() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
optional bool recursive = 2;
getRecursive() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool recursive = 6;
getRecursive() - Method in class alluxio.grpc.SetAttributePOptions
optional bool recursive = 6;
getRecursive() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool recursive = 6;
getRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, we now write one journal entry per inode removed
getRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry
Deprecated, we now write one journal entry per inode removed
getRecursive() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
Deprecated, we now write one journal entry per inode removed
getRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional bool recursive = 5;
getRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry
optional bool recursive = 5;
getRecursive() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional bool recursive = 5;
getRefCount() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
 
getReferenceCount() - Method in class alluxio.concurrent.ClientRWLock
 
getReferenceSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the fixed size of an object reference in this JVM.
getRefreshInterval() - Method in class alluxio.wire.MasterWebUIInit
Gets refresh interval.
getRefreshInterval() - Method in class alluxio.wire.WorkerWebUIInit
Gets refresh interval.
getRegisterCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
getRegisterCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
getRegisterCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
getRegisterCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
getRegisterCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
getRegisterCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
getRegisterCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
getRegisteredServiceDetail(String) - Method in class alluxio.membership.ServiceDiscoveryRecipe
Get the registered service value as ByteBuffer.
getRegisterJobWorkerMethod() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
 
GetRegisterLeasePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetRegisterLeasePOptions
GetRegisterLeasePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetRegisterLeasePOptions
GetRegisterLeasePOptionsOrBuilder - Interface in alluxio.grpc
 
GetRegisterLeasePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetRegisterLeasePRequest
GetRegisterLeasePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetRegisterLeasePRequest
GetRegisterLeasePRequestOrBuilder - Interface in alluxio.grpc
 
GetRegisterLeasePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetRegisterLeasePResponse
GetRegisterLeasePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetRegisterLeasePResponse
GetRegisterLeasePResponseOrBuilder - Interface in alluxio.grpc
 
getRegisterMasterMethod() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
 
getRegisterMasterMethod() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
getRegisterWorkerMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getRegisterWorkerStreamMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getRegistry() - Method in class alluxio.master.MasterProcess
Use only to instantiate SimpleServices.
getRemainingFields() - Method in class alluxio.worker.http.HttpRequestUri
Get the remaining fields of the request URI.
getRemoteHostName() - Method in class alluxio.AbstractClient
 
getRemoteHostName() - Method in interface alluxio.Client
 
getRemoteServiceType() - Method in class alluxio.AbstractClient
 
getRemoteServiceType() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getRemoteServiceType() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getRemoteServiceType() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getRemoteServiceType() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
getRemoteServiceType() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
getRemoteServiceType() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
getRemoteServiceType() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
 
getRemoteServiceType() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getRemoteServiceType() - Method in class alluxio.master.file.FileSystemMasterClient
 
getRemoteServiceType() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
 
getRemoteServiceType() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
 
getRemoteServiceType() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
getRemoteServiceType() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
 
getRemoteServiceType() - Method in class alluxio.worker.block.BlockMasterClient
 
getRemoteServiceType() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getRemoteServiceType() - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
 
getRemoteServiceVersion() - Method in class alluxio.AbstractClient
 
getRemoteSockAddress() - Method in class alluxio.AbstractClient
 
getRemoteSockAddress() - Method in interface alluxio.Client
 
getRemovalMessage(String) - Static method in class alluxio.conf.PropertyKey
 
getRemoveBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getRemovedBlockIds(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the list of removed block ids
getRemovedBlockIds(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the list of removed block ids
getRemovedBlockIds(int) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the list of removed block ids
getRemovedBlockIdsCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the list of removed block ids
getRemovedBlockIdsCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
the list of removed block ids
getRemovedBlockIdsCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the list of removed block ids
getRemovedBlockIdsList() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the list of removed block ids
getRemovedBlockIdsList() - Method in class alluxio.grpc.BlockHeartbeatPRequest
the list of removed block ids
getRemovedBlockIdsList() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the list of removed block ids
getRemovedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the list of blocks removed from this worker in the heartbeat this report represents.
getRemoveDisabledWorkerMethod() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getRemoveMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getRemoveMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getRemovePathConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
getRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
getRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
getRemovePathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
getRemovePathPropertiesBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
getRemovePathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
getRemovePathPropertiesOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
getRemovePathPropertiesOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
getRemovePolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
getRemoveQuorumServerMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
getRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
getRemoveSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
getRemoveSyncPointBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
getRemoveSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
getRemoveSyncPointOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
getRemoveSyncPointOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
getRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRename() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRename() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getRenameMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getRenameOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameEntry rename = 19;
getRenameOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameEntry rename = 19;
getReplicaBlockCount() - Method in class alluxio.wire.MasterWebUIOverview
Gets replica block count.
getReplicationDurable() - Method in class alluxio.client.file.options.OutStreamOptions
 
getReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationDurable = 6;
getReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 replicationDurable = 6;
getReplicationDurable() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 replicationDurable = 6;
getReplicationDurable() - Method in class alluxio.master.file.meta.InodeFile
 
getReplicationDurable() - Method in interface alluxio.master.file.meta.InodeFileView
 
getReplicationDurable() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_durable = 24;
getReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 replication_durable = 24;
getReplicationDurable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 replication_durable = 24;
getReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_durable = 20;
getReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int32 replication_durable = 20;
getReplicationDurable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int32 replication_durable = 20;
getReplicationLimitedFileIds() - Method in class alluxio.master.file.meta.InodeTree
 
getReplicationLimitedFileIds() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getReplicationMax() - Method in class alluxio.client.file.options.OutStreamOptions
 
getReplicationMax() - Method in class alluxio.client.file.URIStatus
 
getReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMax = 4;
getReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 replicationMax = 4;
getReplicationMax() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 replicationMax = 4;
getReplicationMax() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMax = 29;
getReplicationMax() - Method in class alluxio.grpc.FileInfo
optional int32 replicationMax = 29;
getReplicationMax() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 replicationMax = 29;
getReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMax = 7;
getReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions
optional int32 replicationMax = 7;
getReplicationMax() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional int32 replicationMax = 7;
getReplicationMax() - Method in class alluxio.master.file.meta.InodeFile
 
getReplicationMax() - Method in interface alluxio.master.file.meta.InodeFileView
 
getReplicationMax() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_max = 20;
getReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 replication_max = 20;
getReplicationMax() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 replication_max = 20;
getReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_max = 13;
getReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 replication_max = 13;
getReplicationMax() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 replication_max = 13;
getReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_max = 8;
getReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int32 replication_max = 8;
getReplicationMax() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int32 replication_max = 8;
getReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_max = 21;
getReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int32 replication_max = 21;
getReplicationMax() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int32 replication_max = 21;
getReplicationMax() - Method in class alluxio.wire.FileInfo
 
getReplicationMin() - Method in class alluxio.client.file.options.OutStreamOptions
 
getReplicationMin() - Method in class alluxio.client.file.URIStatus
 
getReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMin = 5;
getReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 replicationMin = 5;
getReplicationMin() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 replicationMin = 5;
getReplicationMin() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMin = 30;
getReplicationMin() - Method in class alluxio.grpc.FileInfo
optional int32 replicationMin = 30;
getReplicationMin() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 replicationMin = 30;
getReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMin = 8;
getReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions
optional int32 replicationMin = 8;
getReplicationMin() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional int32 replicationMin = 8;
getReplicationMin() - Method in class alluxio.master.file.meta.InodeFile
 
getReplicationMin() - Method in interface alluxio.master.file.meta.InodeFileView
 
getReplicationMin() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_min = 21;
getReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 replication_min = 21;
getReplicationMin() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 replication_min = 21;
getReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_min = 14;
getReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 replication_min = 14;
getReplicationMin() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 replication_min = 14;
getReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_min = 9;
getReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int32 replication_min = 9;
getReplicationMin() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int32 replication_min = 9;
getReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_min = 22;
getReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int32 replication_min = 22;
getReplicationMin() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int32 replication_min = 22;
getReplicationMin() - Method in class alluxio.wire.FileInfo
 
getReport() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
getReport() - Method in class alluxio.grpc.GetConfigReportPResponse
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
getReport() - Method in interface alluxio.grpc.GetConfigReportPResponseOrBuilder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
getReport() - Method in interface alluxio.worker.block.BlockWorker
Gets a report for the periodic heartbeat to master.
getReportBuilder() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
getReportOrBuilder() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
getReportOrBuilder() - Method in class alluxio.grpc.GetConfigReportPResponse
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
getReportOrBuilder() - Method in interface alluxio.grpc.GetConfigReportPResponseOrBuilder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
getRequest() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
getRequest() - Method in class alluxio.worker.grpc.WriteRequestContext
 
getRequest() - Method in class alluxio.worker.netty.ReadRequestContext
 
getRequest() - Method in class alluxio.worker.netty.WriteRequestContext
 
getRequest() - Method in class alluxio.worker.s3.S3NettyHandler
get HTTP request.
getRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
optional bytes request_body = 1;
getRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest
optional bytes request_body = 1;
getRequestBody() - Method in interface alluxio.grpc.SubmitJobPRequestOrBuilder
optional bytes request_body = 1;
getRequestHeader() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
getRequestHeader() - Method in class alluxio.grpc.TransportMessage
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
getRequestHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
getRequestHeaderBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
getRequestHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
getRequestHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
getRequestHeaderOrBuilder() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
getRequestId() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
optional int64 requestId = 1;
getRequestId() - Method in class alluxio.grpc.MessagingRequestHeader
optional int64 requestId = 1;
getRequestId() - Method in interface alluxio.grpc.MessagingRequestHeaderOrBuilder
optional int64 requestId = 1;
getRequestId() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional int64 requestId = 1;
getRequestId() - Method in class alluxio.grpc.MessagingResponseHeader
optional int64 requestId = 1;
getRequestId() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
optional int64 requestId = 1;
getRequestId() - Method in class alluxio.s3.S3Error
 
getRequestLatestSnapshotDataMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
 
getRequestLatestSnapshotInfoMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
 
getRequestMarshaller() - Method in class alluxio.grpc.DataMessageMarshallerProvider
 
getRequestRegisterLeaseMethod() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getRequestType(RequestType) - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
getReservedBytes() - Method in interface alluxio.worker.block.meta.StorageDir
 
getResetPrioritiesMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getResource() - Method in class alluxio.s3.S3Error
 
getResource() - Method in exception alluxio.s3.S3Exception
 
getResourcePoolMetricName(Object) - Static method in class alluxio.metrics.MetricsSystem
Get metrics name based on class.
getResources(String) - Method in class alluxio.extensions.ExtensionsClassLoader
 
getResponse() - Method in class alluxio.worker.s3.S3NettyHandler
get HTTP response.
getResponseEventFactory() - Static method in class alluxio.client.file.dora.netty.event.ResponseEventFactory
Get a response event factory.
getResponseFuture() - Method in class alluxio.scheduler.job.Task
 
getResponseHeader() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
getResponseHeader() - Method in class alluxio.grpc.TransportMessage
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
getResponseHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
getResponseHeaderBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
getResponseHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
getResponseHeaderOrBuilder() - Method in class alluxio.grpc.TransportMessage
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
getResponseHeaderOrBuilder() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
getResponseMarshaller() - Method in class alluxio.grpc.DataMessageMarshallerProvider
 
getRestS3LocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getRestS3LocalPort() - Method in interface alluxio.worker.WorkerProcess
 
getResult() - Method in class alluxio.cli.ValidationResults
Get Validation Result.
getResult() - Method in class alluxio.cli.ValidationTaskResult
 
getResult() - Method in class alluxio.grpc.JobInfo.Builder
optional bytes result = 9;
getResult() - Method in class alluxio.grpc.JobInfo
optional bytes result = 9;
getResult() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional bytes result = 9;
getResult() - Method in class alluxio.job.plan.meta.PlanInfo
 
getResult() - Method in interface alluxio.job.wire.JobInfo
 
getResult() - Method in class alluxio.job.wire.PlanInfo
 
getResult() - Method in class alluxio.job.wire.TaskInfo
 
getResult() - Method in class alluxio.job.wire.WorkflowInfo
 
getResult() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Gets the combined result from all batches.
getRetryable() - Method in class alluxio.grpc.BlockStatus.Builder
optional bool retryable = 4;
getRetryable() - Method in class alluxio.grpc.BlockStatus
optional bool retryable = 4;
getRetryable() - Method in interface alluxio.grpc.BlockStatusOrBuilder
optional bool retryable = 4;
getRetryable() - Method in class alluxio.grpc.FileFailure.Builder
optional bool retryable = 4;
getRetryable() - Method in class alluxio.grpc.FileFailure
optional bool retryable = 4;
getRetryable() - Method in interface alluxio.grpc.FileFailureOrBuilder
optional bool retryable = 4;
getRetryable() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional bool retryable = 4;
getRetryable() - Method in class alluxio.grpc.LoadFileFailure
optional bool retryable = 4;
getRetryable() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
optional bool retryable = 4;
getRetryable() - Method in class alluxio.grpc.RouteFailure.Builder
optional bool retryable = 4;
getRetryable() - Method in class alluxio.grpc.RouteFailure
optional bool retryable = 4;
getRetryable() - Method in interface alluxio.grpc.RouteFailureOrBuilder
optional bool retryable = 4;
getRetryDelay() - Method in class alluxio.proxy.s3.MultipartUploadCleaner
Get retry delay.
getRetryPolicySupplier() - Method in class alluxio.common.RpcPortHealthCheckClient
 
getReverseResolveMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getRevision() - Method in class alluxio.grpc.BuildVersion.Builder
the git revision at the time of building
getRevision() - Method in class alluxio.grpc.BuildVersion
the git revision at the time of building
getRevision() - Method in interface alluxio.grpc.BuildVersionOrBuilder
the git revision at the time of building
getRevision() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string revision = 5;
getRevision() - Method in class alluxio.grpc.RegisterMasterPOptions
optional string revision = 5;
getRevision() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional string revision = 5;
getRevision() - Method in class alluxio.master.meta.MasterInfo
 
getRevision() - Method in class alluxio.master.meta.ProxyInfo
 
getRevision() - Method in class alluxio.util.webui.NodeInfo
Gets worker revision.
getRevision() - Method in class alluxio.wire.AlluxioMasterInfo
Gets revision.
getRevision() - Method in class alluxio.wire.AlluxioWorkerInfo
Gets revision.
getRevision() - Method in class alluxio.wire.MasterInfo
 
getRevision() - Method in class alluxio.wire.MasterWebUIOverview
Gets revision.
getRevision() - Method in class alluxio.wire.WorkerInfo
 
getRevision() - Method in class alluxio.wire.WorkerWebUIOverview
Gets revision.
getRevisionBytes() - Method in class alluxio.grpc.BuildVersion.Builder
the git revision at the time of building
getRevisionBytes() - Method in class alluxio.grpc.BuildVersion
the git revision at the time of building
getRevisionBytes() - Method in interface alluxio.grpc.BuildVersionOrBuilder
the git revision at the time of building
getRevisionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string revision = 5;
getRevisionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions
optional string revision = 5;
getRevisionBytes() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional string revision = 5;
getRevisionNumber() - Method in class alluxio.membership.DefaultServiceEntity
Get the revision number of currently registered DefaultServiceEntity on ETCD.
getRocksStore() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
getRocksStore() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
getRocksStore() - Method in interface alluxio.rocks.RocksCheckpointed
 
getRole() - Method in class alluxio.cli.LogLevel.TargetInfo
 
getRoleId() - Method in class alluxio.master.journal.raft.RaftJournalSystem
Get the role index.
getRoleServices() - Method in class alluxio.master.backup.BackupLeaderRole
 
getRoleServices() - Method in interface alluxio.master.backup.BackupRole
 
getRoleServices() - Method in class alluxio.master.backup.BackupWorkerRole
 
getRoot() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the root of the current computation; i.e., this task if it has no completer, else its completer's root.
getRoot() - Method in class alluxio.master.file.meta.InodeTree
 
getRoot() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getRoot() - Method in class alluxio.underfs.AbstractUfsManager
 
getRoot() - Method in interface alluxio.underfs.UfsManager
 
getRootCause(Throwable) - Static method in class alluxio.util.CommonUtils
Gets the root cause of an exception.
getRootDir() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getRootInodeOwner() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getRootInodeOwner() - Method in interface alluxio.master.file.FileSystemMaster
 
getRootKey() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get full path of root in object store.
getRootKey() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getRootKey() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getRootPath() - Method in class alluxio.AlluxioURI
 
getRootPath() - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
getRoots() - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads of all the root nodes of the DAG.
getRootUFS() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
Gets the UFS Root.
getRootUfsUri() - Method in class alluxio.fuse.options.FuseCliOptions
 
getRootUserName() - Method in class alluxio.master.file.meta.InodeTree
 
getRoute() - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
getRoute() - Method in class alluxio.grpc.RouteFailure
required .alluxio.grpc.block.Route route = 1;
getRoute() - Method in interface alluxio.grpc.RouteFailureOrBuilder
required .alluxio.grpc.block.Route route = 1;
getRouteBuilder() - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
getRouteOrBuilder() - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
getRouteOrBuilder() - Method in class alluxio.grpc.RouteFailure
required .alluxio.grpc.block.Route route = 1;
getRouteOrBuilder() - Method in interface alluxio.grpc.RouteFailureOrBuilder
required .alluxio.grpc.block.Route route = 1;
getRoutes(int) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutes(int) - Method in class alluxio.grpc.CopyRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutes(int) - Method in interface alluxio.grpc.CopyRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutes(int) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutes(int) - Method in class alluxio.grpc.MoveRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutes(int) - Method in interface alluxio.grpc.MoveRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutes() - Method in class alluxio.master.job.CopyJob.CopyTask
 
getRoutes() - Method in class alluxio.master.job.MoveJob.MoveTask
 
getRoutesBuilder(int) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesBuilder(int) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesBuilderList() - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesBuilderList() - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesCount() - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesCount() - Method in class alluxio.grpc.CopyRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesCount() - Method in interface alluxio.grpc.CopyRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesCount() - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesCount() - Method in class alluxio.grpc.MoveRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesCount() - Method in interface alluxio.grpc.MoveRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesList() - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesList() - Method in class alluxio.grpc.CopyRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesList() - Method in interface alluxio.grpc.CopyRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesList() - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesList() - Method in class alluxio.grpc.MoveRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesList() - Method in interface alluxio.grpc.MoveRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilder(int) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilder(int) - Method in class alluxio.grpc.CopyRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilder(int) - Method in interface alluxio.grpc.CopyRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilder(int) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilder(int) - Method in class alluxio.grpc.MoveRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilder(int) - Method in interface alluxio.grpc.MoveRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilderList() - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilderList() - Method in class alluxio.grpc.CopyRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilderList() - Method in interface alluxio.grpc.CopyRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilderList() - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilderList() - Method in class alluxio.grpc.MoveRequest
repeated .alluxio.grpc.block.Route routes = 1;
getRoutesOrBuilderList() - Method in interface alluxio.grpc.MoveRequestOrBuilder
repeated .alluxio.grpc.block.Route routes = 1;
getRpcAddress() - Method in class alluxio.master.MasterProcess
 
getRpcAddress() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getRpcAddress() - Method in interface alluxio.master.meta.MetaMaster
 
getRpcAddress() - Method in class alluxio.wire.AlluxioMasterInfo
 
getRpcAddress() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getRpcAddress() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
getRpcAddress() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getRpcAddress() - Method in interface alluxio.worker.JobWorkerProcess
 
getRpcAddress() - Method in interface alluxio.worker.WorkerProcess
 
getRpcBindAddress() - Method in class alluxio.master.MasterProcess
 
getRpcInvocationMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
Gets rpc invocation metrics.
getRpcLocalPort() - Method in class alluxio.master.LocalAlluxioMaster
Gets the actual port that the RPC service is listening on.
getRpcPort() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get rpc port.
getRpcPort() - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 rpcPort = 3;
getRpcPort() - Method in class alluxio.grpc.MasterInfo
optional int32 rpcPort = 3;
getRpcPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int32 rpcPort = 3;
getRpcPort() - Method in class alluxio.grpc.NetAddress.Builder
optional int32 rpcPort = 2;
getRpcPort() - Method in class alluxio.grpc.NetAddress
optional int32 rpcPort = 2;
getRpcPort() - Method in interface alluxio.grpc.NetAddressOrBuilder
optional int32 rpcPort = 2;
getRpcPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 rpcPort = 2;
getRpcPort() - Method in class alluxio.grpc.WorkerNetAddress
optional int32 rpcPort = 2;
getRpcPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional int32 rpcPort = 2;
getRpcPort() - Method in class alluxio.multi.process.MasterNetAddress
 
getRpcPort() - Method in class alluxio.wire.Address
 
getRpcPort() - Method in class alluxio.wire.WorkerNetAddress
 
getRpcPortSocketAddress(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Extracts rpcPort socket address from Alluxio representation of network address.
getRpcQueueLength() - Method in class alluxio.master.AlluxioExecutorService
 
getRpcQueueLength() - Method in class alluxio.wire.WorkerWebUIOperations
Gets the current RPC queue length.
getRunAsync() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool runAsync = 2;
getRunAsync() - Method in class alluxio.grpc.BackupPOptions
optional bool runAsync = 2;
getRunAsync() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool runAsync = 2;
getRunLimit(long) - Method in class alluxio.heartbeat.CronExpressionIntervalSupplier
 
getRunLimit(long) - Method in class alluxio.heartbeat.FixedIntervalSupplier
 
getRunLimit(long) - Method in interface alluxio.heartbeat.SleepIntervalSupplier
Gets the run limit from previous ticked.
getRunMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getRunningThreadCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks or for other managed synchronization.
getRunTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
getRunTaskCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
getRunTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
getRunTaskCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
getRunTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
getRunTaskCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
getRunTaskCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
getS3BindAddress() - Method in interface alluxio.worker.DataServer
Gets the actual bind socket address for S3.
getS3BindAddress() - Method in class alluxio.worker.grpc.GrpcDataServer
 
getS3BindAddress() - Method in class alluxio.worker.netty.NettyDataServer
 
getS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
getS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
getS3SyntaxOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
getS3SyntaxOptionsBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
getS3SyntaxOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
getS3SyntaxOptionsOrBuilder() - Method in class alluxio.grpc.RenamePOptions
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
getS3SyntaxOptionsOrBuilder() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
getS3Task() - Method in class alluxio.proxy.s3.S3Handler
get S3Task of this S3Handler.
getS3Task() - Method in class alluxio.worker.s3.S3NettyHandler
get S3Task of this S3Handler.
getS3WriteType() - Static method in class alluxio.proxy.s3.S3RestUtils
 
getSafeMode() - Method in class alluxio.grpc.MasterInfo.Builder
optional bool safeMode = 4;
getSafeMode() - Method in class alluxio.grpc.MasterInfo
optional bool safeMode = 4;
getSafeMode() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional bool safeMode = 4;
getSafeModeManager() - Method in class alluxio.master.AlluxioMasterProcess
 
getSafeModeManager() - Method in class alluxio.master.CoreMasterContext
 
getSafeModeManager() - Method in class alluxio.master.MasterProcess
 
getScale() - Method in class alluxio.grpc.table.Decimal.Builder
force using scale first in Decimal.compareTo
getScale() - Method in class alluxio.grpc.table.Decimal
force using scale first in Decimal.compareTo
getScale() - Method in interface alluxio.grpc.table.DecimalOrBuilder
force using scale first in Decimal.compareTo
getScanCompleted() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanCompleted = 4;
getScanCompleted() - Method in class alluxio.grpc.PolicyStatus
optional int64 scanCompleted = 4;
getScanCompleted() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 scanCompleted = 4;
getScanPendingAction() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanPendingAction = 3;
getScanPendingAction() - Method in class alluxio.grpc.PolicyStatus
optional int64 scanPendingAction = 3;
getScanPendingAction() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 scanPendingAction = 3;
getScanStartedMs() - Method in class alluxio.grpc.PolicyStatus.Builder
scan status
getScanStartedMs() - Method in class alluxio.grpc.PolicyStatus
scan status
getScanStartedMs() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
scan status
getScanTotal() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanTotal = 2;
getScanTotal() - Method in class alluxio.grpc.PolicyStatus
optional int64 scanTotal = 2;
getScanTotal() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 scanTotal = 2;
getScheduleAsyncPersistenceMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getScheduler() - Method in class alluxio.master.file.DefaultFileSystemMaster
Get scheduler.
getScheduler() - Method in interface alluxio.master.file.FileSystemMaster
 
getSchedulerInfo(String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
getSchema() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
getSchema() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.Schema schema = 5;
getSchema() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.Schema schema = 5;
getSchemaBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
getSchemaOrBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
getSchemaOrBuilder() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.Schema schema = 5;
getSchemaOrBuilder() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.Schema schema = 5;
getScheme() - Method in class alluxio.AlluxioURI
Gets the scheme of the AlluxioURI.
getScheme() - Method in class alluxio.hadoop.AbstractFileSystem
Gets the URI scheme that maps to the FileSystem.
getScheme() - Method in class alluxio.hadoop.FileSystem
 
getScheme() - Method in class alluxio.hadoop.LocalCacheFileSystem
 
getScheme(HttpRequest) - Static method in class alluxio.s3.NettyRestUtils
Get the scheme of a HttpRequest.
getScheme() - Method in class alluxio.uri.MultiPartSchemeURI
 
getScheme() - Method in class alluxio.uri.StandardURI
 
getScheme() - Method in interface alluxio.uri.URI
 
getSchemeAuthority(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
getSchemeComponents(String) - Static method in class alluxio.uri.URI.Factory
Returns a Pair of components of the given scheme.
getSchemeSpecificPart() - Method in class alluxio.uri.StandardURI
 
getSchemeSpecificPart() - Method in interface alluxio.uri.URI
 
getScope() - Method in class alluxio.client.file.cache.PageInfo
 
getScope() - Method in class alluxio.conf.PropertyKey
 
getSecond() - Method in class alluxio.collections.Pair
 
getSecureRpcPort() - Method in class alluxio.wire.WorkerNetAddress
 
getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.MasterWebUIInit
Gets security authorization permission enabled.
getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.WorkerWebUIInit
Gets security authorization permission enabled.
getSegmentIndex(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
 
getSegmentStartPos(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
 
getSelectionPolicy() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getSelfSignedClientSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getSelfSignedClientSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getSelfSignedServerSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getSelfSignedServerSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getSequenceNumber(long) - Static method in class alluxio.master.block.BlockId
 
getSequenceNumber() - Method in class alluxio.master.file.state.DirectoryId
 
getSequenceNumber() - Method in interface alluxio.master.file.state.DirectoryId.UnmodifiableDirectoryId
 
getSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 sequence_number = 2;
getSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
optional int64 sequence_number = 2;
getSequenceNumber() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
optional int64 sequence_number = 2;
getSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
shared fields.
getSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
shared fields.
getSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
shared fields.
getSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string serde = 1;
getSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string serde = 1;
getSerde() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string serde = 1;
getSerdeBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string serde = 1;
getSerdeBytes() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string serde = 1;
getSerdeBytes() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string serde = 1;
getSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
Deprecated.
getSerdelibParameters() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
Deprecated.
getSerdelibParameters() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
Deprecated.
getSerdelibParametersCount() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
getSerdelibParametersCount() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
getSerdelibParametersCount() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
map<string, string> serdelib_parameters = 4;
getSerdelibParametersMap() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
map<string, string> serdelib_parameters = 4;
getSerdelibParametersMap() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
map<string, string> serdelib_parameters = 4;
getSerdelibParametersMap() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
map<string, string> serdelib_parameters = 4;
getSerdelibParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
map<string, string> serdelib_parameters = 4;
getSerdelibParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
map<string, string> serdelib_parameters = 4;
getSerdelibParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
map<string, string> serdelib_parameters = 4;
getSerdelibParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
map<string, string> serdelib_parameters = 4;
getSerdelibParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
map<string, string> serdelib_parameters = 4;
getSerdelibParametersOrThrow(String) - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
map<string, string> serdelib_parameters = 4;
getSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
Deprecated.
getSerdeParameters() - Method in class alluxio.grpc.table.layout.hive.Storage
Deprecated.
getSerdeParameters() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
Deprecated.
getSerdeParametersCount() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
getSerdeParametersCount() - Method in class alluxio.grpc.table.layout.hive.Storage
 
getSerdeParametersCount() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
map<string, string> serde_parameters = 5;
getSerdeParametersMap() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
map<string, string> serde_parameters = 5;
getSerdeParametersMap() - Method in class alluxio.grpc.table.layout.hive.Storage
map<string, string> serde_parameters = 5;
getSerdeParametersMap() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
map<string, string> serde_parameters = 5;
getSerdeParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
map<string, string> serde_parameters = 5;
getSerdeParametersOrDefault(String, String) - Method in class alluxio.grpc.table.layout.hive.Storage
map<string, string> serde_parameters = 5;
getSerdeParametersOrDefault(String, String) - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
map<string, string> serde_parameters = 5;
getSerdeParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
map<string, string> serde_parameters = 5;
getSerdeParametersOrThrow(String) - Method in class alluxio.grpc.table.layout.hive.Storage
map<string, string> serde_parameters = 5;
getSerdeParametersOrThrow(String) - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
map<string, string> serde_parameters = 5;
getSerializedSize() - Method in class alluxio.grpc.ActionInfo
 
getSerializedSize() - Method in class alluxio.grpc.AddPolicyPOptions
 
getSerializedSize() - Method in class alluxio.grpc.AddPolicyPRequest
 
getSerializedSize() - Method in class alluxio.grpc.AddPolicyPResponse
 
getSerializedSize() - Method in class alluxio.grpc.AddQuorumServerRequest
 
getSerializedSize() - Method in class alluxio.grpc.AsyncCacheRequest
 
getSerializedSize() - Method in class alluxio.grpc.AsyncCacheResponse
 
getSerializedSize() - Method in class alluxio.grpc.BackupPOptions
 
getSerializedSize() - Method in class alluxio.grpc.BackupPRequest
 
getSerializedSize() - Method in class alluxio.grpc.BackupPStatus
 
getSerializedSize() - Method in class alluxio.grpc.BackupStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.Block
 
getSerializedSize() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
getSerializedSize() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
getSerializedSize() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
getSerializedSize() - Method in class alluxio.grpc.BlockIdList
 
getSerializedSize() - Method in class alluxio.grpc.BlockInfo
 
getSerializedSize() - Method in class alluxio.grpc.BlockLocation
 
getSerializedSize() - Method in class alluxio.grpc.BlockMasterInfo
 
getSerializedSize() - Method in class alluxio.grpc.BlockStatus
 
getSerializedSize() - Method in class alluxio.grpc.BlockStoreLocationProto
 
getSerializedSize() - Method in class alluxio.grpc.BuildVersion
 
getSerializedSize() - Method in class alluxio.grpc.CacheRequest
 
getSerializedSize() - Method in class alluxio.grpc.CacheResponse
 
getSerializedSize() - Method in class alluxio.grpc.CancelPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CancelPRequest
 
getSerializedSize() - Method in class alluxio.grpc.CancelPResponse
 
getSerializedSize() - Method in class alluxio.grpc.CancelTaskCommand
 
getSerializedSize() - Method in class alluxio.grpc.CheckAccessPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CheckAccessPRequest
 
getSerializedSize() - Method in class alluxio.grpc.CheckAccessPResponse
 
getSerializedSize() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
getSerializedSize() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
getSerializedSize() - Method in class alluxio.grpc.CheckpointPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CheckpointPResponse
 
getSerializedSize() - Method in class alluxio.grpc.CheckRequest
 
getSerializedSize() - Method in class alluxio.grpc.CheckResponse
 
getSerializedSize() - Method in class alluxio.grpc.Chunk
 
getSerializedSize() - Method in class alluxio.grpc.ClearMetricsPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ClearMetricsPResponse
 
getSerializedSize() - Method in class alluxio.grpc.ClearMetricsRequest
 
getSerializedSize() - Method in class alluxio.grpc.ClearMetricsResponse
 
getSerializedSize() - Method in class alluxio.grpc.ClientMetrics
 
getSerializedSize() - Method in class alluxio.grpc.CmdProgress
 
getSerializedSize() - Method in class alluxio.grpc.CmdStatusBlock
 
getSerializedSize() - Method in class alluxio.grpc.CmdSummary
 
getSerializedSize() - Method in class alluxio.grpc.Command
 
getSerializedSize() - Method in class alluxio.grpc.CommitBlockPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CommitBlockPRequest
 
getSerializedSize() - Method in class alluxio.grpc.CommitBlockPResponse
 
getSerializedSize() - Method in class alluxio.grpc.CompleteFilePOptions
 
getSerializedSize() - Method in class alluxio.grpc.CompleteFilePRequest
 
getSerializedSize() - Method in class alluxio.grpc.CompleteFilePResponse
 
getSerializedSize() - Method in class alluxio.grpc.ConfigCheckReport
 
getSerializedSize() - Method in class alluxio.grpc.ConfigProperties
 
getSerializedSize() - Method in class alluxio.grpc.ConfigProperty
 
getSerializedSize() - Method in class alluxio.grpc.CopyJobPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CopyRequest
 
getSerializedSize() - Method in class alluxio.grpc.CopyResponse
 
getSerializedSize() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
getSerializedSize() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
getSerializedSize() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
getSerializedSize() - Method in class alluxio.grpc.CreateFilePOptions
 
getSerializedSize() - Method in class alluxio.grpc.CreateFilePRequest
 
getSerializedSize() - Method in class alluxio.grpc.CreateFilePResponse
 
getSerializedSize() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
getSerializedSize() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
getSerializedSize() - Method in class alluxio.grpc.DeletePOptions
 
getSerializedSize() - Method in class alluxio.grpc.DeletePRequest
 
getSerializedSize() - Method in class alluxio.grpc.DeletePResponse
 
getSerializedSize() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.ErrorInfo
 
getSerializedSize() - Method in class alluxio.grpc.ExistsPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ExistsPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ExistsPResponse
 
getSerializedSize() - Method in class alluxio.grpc.File
 
getSerializedSize() - Method in class alluxio.grpc.FileBlockInfo
 
getSerializedSize() - Method in class alluxio.grpc.FileFailure
 
getSerializedSize() - Method in class alluxio.grpc.FileInfo
 
getSerializedSize() - Method in class alluxio.grpc.FileSystemCommand
 
getSerializedSize() - Method in class alluxio.grpc.FileSystemCommandOptions
 
getSerializedSize() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
getSerializedSize() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
getSerializedSize() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
getSerializedSize() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
getSerializedSize() - Method in class alluxio.grpc.FreePOptions
 
getSerializedSize() - Method in class alluxio.grpc.FreePRequest
 
getSerializedSize() - Method in class alluxio.grpc.FreePResponse
 
getSerializedSize() - Method in class alluxio.grpc.FreeWorkerRequest
 
getSerializedSize() - Method in class alluxio.grpc.FreeWorkerResponse
 
getSerializedSize() - Method in class alluxio.grpc.FsOpPId
 
getSerializedSize() - Method in class alluxio.grpc.GetActionInfoOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetActionInfoRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetActionInfoResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetCmdStatusResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetConfigHashPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetConfigHashPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetConfigReportPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetConfigReportPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetConfigurationPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetConfigurationPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetFileInfoPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetFileInfoPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetFileInfoPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetFilePathPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetFilePathPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetJobProgressPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetJobProgressPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetJobStatusPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetJobStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetJobStatusPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetMasterIdPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetMasterIdPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetMasterIdPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetMetricsPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetMetricsPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetMountIdPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetMountIdPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetMountTablePRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetMountTablePResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetNodeStatePRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetNodeStatePResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetStatusPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetStatusPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
getSerializedSize() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
getSerializedSize() - Method in class alluxio.grpc.InconsistentProperties
 
getSerializedSize() - Method in class alluxio.grpc.InconsistentProperty
 
getSerializedSize() - Method in class alluxio.grpc.InconsistentPropertyValues
 
getSerializedSize() - Method in class alluxio.grpc.JobCommand
 
getSerializedSize() - Method in class alluxio.grpc.JobDescription
 
getSerializedSize() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
getSerializedSize() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
getSerializedSize() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
getSerializedSize() - Method in class alluxio.grpc.JobInfo
 
getSerializedSize() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
getSerializedSize() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
getSerializedSize() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
getSerializedSize() - Method in class alluxio.grpc.JobMasterStatus
 
getSerializedSize() - Method in class alluxio.grpc.JobProgress
 
getSerializedSize() - Method in class alluxio.grpc.JobProgressPOptions
 
getSerializedSize() - Method in class alluxio.grpc.JobServiceSummary
 
getSerializedSize() - Method in class alluxio.grpc.JobStatusBlock
 
getSerializedSize() - Method in class alluxio.grpc.JobUnused
 
getSerializedSize() - Method in class alluxio.grpc.JobWorkerHealth
 
getSerializedSize() - Method in class alluxio.grpc.JournalQueryRequest
 
getSerializedSize() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ListAllPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ListAllPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ListAllPResponse
 
getSerializedSize() - Method in class alluxio.grpc.ListPolicyPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ListPolicyPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ListPolicyPResponse
 
getSerializedSize() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ListStatusPResponse
 
getSerializedSize() - Method in class alluxio.grpc.LoadFileFailure
 
getSerializedSize() - Method in class alluxio.grpc.LoadFileRequest
 
getSerializedSize() - Method in class alluxio.grpc.LoadFileResponse
 
getSerializedSize() - Method in class alluxio.grpc.LoadJobPOptions
 
getSerializedSize() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getSerializedSize() - Method in class alluxio.grpc.LoadRequest
 
getSerializedSize() - Method in class alluxio.grpc.LoadResponse
 
getSerializedSize() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
getSerializedSize() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
getSerializedSize() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
getSerializedSize() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
getSerializedSize() - Method in class alluxio.grpc.MasterInfo
 
getSerializedSize() - Method in class alluxio.grpc.MasterVersion
 
getSerializedSize() - Method in class alluxio.grpc.MessagingRequestHeader
 
getSerializedSize() - Method in class alluxio.grpc.MessagingResponseHeader
 
getSerializedSize() - Method in class alluxio.grpc.Metric
 
getSerializedSize() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
getSerializedSize() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
getSerializedSize() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
getSerializedSize() - Method in class alluxio.grpc.MetricValue
 
getSerializedSize() - Method in class alluxio.grpc.MountPointInfo
 
getSerializedSize() - Method in class alluxio.grpc.MountPOptions
 
getSerializedSize() - Method in class alluxio.grpc.MountPRequest
 
getSerializedSize() - Method in class alluxio.grpc.MountPResponse
 
getSerializedSize() - Method in class alluxio.grpc.MoveBlockRequest
 
getSerializedSize() - Method in class alluxio.grpc.MoveBlockResponse
 
getSerializedSize() - Method in class alluxio.grpc.MoveJobPOptions
 
getSerializedSize() - Method in class alluxio.grpc.MoveRequest
 
getSerializedSize() - Method in class alluxio.grpc.MoveResponse
 
getSerializedSize() - Method in class alluxio.grpc.NeedsSyncRequest
 
getSerializedSize() - Method in class alluxio.grpc.NeedsSyncResponse
 
getSerializedSize() - Method in class alluxio.grpc.NetAddress
 
getSerializedSize() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
getSerializedSize() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
getSerializedSize() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
getSerializedSize() - Method in class alluxio.grpc.OpenFilePOptions
 
getSerializedSize() - Method in class alluxio.grpc.PAcl
 
getSerializedSize() - Method in class alluxio.grpc.PAclEntry
 
getSerializedSize() - Method in class alluxio.grpc.PersistCommandOptions
 
getSerializedSize() - Method in class alluxio.grpc.PersistFile
 
getSerializedSize() - Method in class alluxio.grpc.PMode
 
getSerializedSize() - Method in class alluxio.grpc.PolicyInfo
 
getSerializedSize() - Method in class alluxio.grpc.PolicyStatus
 
getSerializedSize() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
getSerializedSize() - Method in class alluxio.grpc.ProxyStatus
 
getSerializedSize() - Method in class alluxio.grpc.QuorumServerInfo
 
getSerializedSize() - Method in class alluxio.grpc.ReadRequest
 
getSerializedSize() - Method in class alluxio.grpc.ReadResponse
 
getSerializedSize() - Method in class alluxio.grpc.RegisterCommand
 
getSerializedSize() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RegisterMasterPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RegisterMasterPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RegisterMasterPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RemoveBlockRequest
 
getSerializedSize() - Method in class alluxio.grpc.RemoveBlockResponse
 
getSerializedSize() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RemovePolicyPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RemovePolicyPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RemovePolicyPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RenamePOptions
 
getSerializedSize() - Method in class alluxio.grpc.RenamePRequest
 
getSerializedSize() - Method in class alluxio.grpc.RenamePResponse
 
getSerializedSize() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
getSerializedSize() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
getSerializedSize() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RetryInfo
 
getSerializedSize() - Method in class alluxio.grpc.ReverseResolvePRequest
 
getSerializedSize() - Method in class alluxio.grpc.ReverseResolvePResponse
 
getSerializedSize() - Method in class alluxio.grpc.Route
 
getSerializedSize() - Method in class alluxio.grpc.RouteFailure
 
getSerializedSize() - Method in class alluxio.grpc.RunPOptions
 
getSerializedSize() - Method in class alluxio.grpc.RunPRequest
 
getSerializedSize() - Method in class alluxio.grpc.RunPResponse
 
getSerializedSize() - Method in class alluxio.grpc.RunTaskCommand
 
getSerializedSize() - Method in class alluxio.grpc.S3SyntaxOptions
 
getSerializedSize() - Method in class alluxio.grpc.SaslMessage
 
getSerializedSize() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
getSerializedSize() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
getSerializedSize() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
getSerializedSize() - Method in class alluxio.grpc.SetAclPOptions
 
getSerializedSize() - Method in class alluxio.grpc.SetAclPRequest
 
getSerializedSize() - Method in class alluxio.grpc.SetAclPResponse
 
getSerializedSize() - Method in class alluxio.grpc.SetAttributePOptions
 
getSerializedSize() - Method in class alluxio.grpc.SetAttributePRequest
 
getSerializedSize() - Method in class alluxio.grpc.SetAttributePResponse
 
getSerializedSize() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
getSerializedSize() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
getSerializedSize() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
getSerializedSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
getSerializedSize() - Method in class alluxio.grpc.SnapshotData
 
getSerializedSize() - Method in class alluxio.grpc.SnapshotMetadata
 
getSerializedSize() - Method in class alluxio.grpc.StatusSummary
 
getSerializedSize() - Method in class alluxio.grpc.StopJobPRequest
 
getSerializedSize() - Method in class alluxio.grpc.StopJobPResponse
 
getSerializedSize() - Method in class alluxio.grpc.StorageList
 
getSerializedSize() - Method in class alluxio.grpc.SubmitJobPRequest
 
getSerializedSize() - Method in class alluxio.grpc.SubmitJobPResponse
 
getSerializedSize() - Method in class alluxio.grpc.SubmitOptions
 
getSerializedSize() - Method in class alluxio.grpc.SubmitRequest
 
getSerializedSize() - Method in class alluxio.grpc.SubmitResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.AllOrNoneSet
 
getSerializedSize() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
getSerializedSize() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
getSerializedSize() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
getSerializedSize() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
getSerializedSize() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
getSerializedSize() - Method in class alluxio.grpc.table.Constraint
 
getSerializedSize() - Method in class alluxio.grpc.table.Database
 
getSerializedSize() - Method in class alluxio.grpc.table.Date
 
getSerializedSize() - Method in class alluxio.grpc.table.DateColumnStatsData
 
getSerializedSize() - Method in class alluxio.grpc.table.Decimal
 
getSerializedSize() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
getSerializedSize() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.Domain
 
getSerializedSize() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
getSerializedSize() - Method in class alluxio.grpc.table.EquatableValueSet
 
getSerializedSize() - Method in class alluxio.grpc.table.FieldSchema
 
getSerializedSize() - Method in class alluxio.grpc.table.FileStatistics
 
getSerializedSize() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.GetTablePRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.GetTablePResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.Layout
 
getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.Storage
 
getSerializedSize() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
getSerializedSize() - Method in class alluxio.grpc.table.LayoutSpec
 
getSerializedSize() - Method in class alluxio.grpc.table.LongColumnStatsData
 
getSerializedSize() - Method in class alluxio.grpc.table.Partition
 
getSerializedSize() - Method in class alluxio.grpc.table.PartitionSpec
 
getSerializedSize() - Method in class alluxio.grpc.table.Range
 
getSerializedSize() - Method in class alluxio.grpc.table.RangeSet
 
getSerializedSize() - Method in class alluxio.grpc.table.ReadTablePRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.ReadTablePResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.Schema
 
getSerializedSize() - Method in class alluxio.grpc.table.StringColumnStatsData
 
getSerializedSize() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.SyncStatus
 
getSerializedSize() - Method in class alluxio.grpc.table.TableInfo
 
getSerializedSize() - Method in class alluxio.grpc.table.Transformation
 
getSerializedSize() - Method in class alluxio.grpc.table.TransformJobInfo
 
getSerializedSize() - Method in class alluxio.grpc.table.TransformTablePRequest
 
getSerializedSize() - Method in class alluxio.grpc.table.TransformTablePResponse
 
getSerializedSize() - Method in class alluxio.grpc.table.Value
 
getSerializedSize() - Method in class alluxio.grpc.TierList
 
getSerializedSize() - Method in class alluxio.grpc.TransferLeaderMessage
 
getSerializedSize() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
getSerializedSize() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
getSerializedSize() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
getSerializedSize() - Method in class alluxio.grpc.TransportMessage
 
getSerializedSize() - Method in class alluxio.grpc.TriggerPolicyRequest
 
getSerializedSize() - Method in class alluxio.grpc.TriggerPolicyResponse
 
getSerializedSize() - Method in class alluxio.grpc.UfsFileStatus
 
getSerializedSize() - Method in class alluxio.grpc.UfsInfo
 
getSerializedSize() - Method in class alluxio.grpc.UfsReadOptions
 
getSerializedSize() - Method in class alluxio.grpc.UfsStatus
 
getSerializedSize() - Method in class alluxio.grpc.UnmountPOptions
 
getSerializedSize() - Method in class alluxio.grpc.UnmountPRequest
 
getSerializedSize() - Method in class alluxio.grpc.UnmountPResponse
 
getSerializedSize() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
getSerializedSize() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
getSerializedSize() - Method in class alluxio.grpc.UpdateMountPRequest
 
getSerializedSize() - Method in class alluxio.grpc.UpdateMountPResponse
 
getSerializedSize() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
getSerializedSize() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
getSerializedSize() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
getSerializedSize() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
getSerializedSize() - Method in class alluxio.grpc.WorkerIdentity
 
getSerializedSize() - Method in class alluxio.grpc.WorkerInfo
 
getSerializedSize() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getSerializedSize() - Method in class alluxio.grpc.WorkerNetAddress
 
getSerializedSize() - Method in class alluxio.grpc.WriteOptions
 
getSerializedSize() - Method in class alluxio.grpc.WriteRequest
 
getSerializedSize() - Method in class alluxio.grpc.WriteRequestCommand
 
getSerializedSize() - Method in class alluxio.grpc.WriteResponse
 
getSerializedSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
getSerializedSize() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getSerializedSize() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getSerializedSize() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.RenameEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.SetAclEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.StringPairEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Job.FileFilter
 
getSerializedSize() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
getSerializedSize() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
getSerializedSize() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
getSerializedSize() - Method in class alluxio.proto.meta.Block.BlockLocation
 
getSerializedSize() - Method in class alluxio.proto.meta.Block.BlockMeta
 
getSerializedSize() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
getSerializedSize() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
getSerializedSize() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
getSerializedSize() - Method in class alluxio.proto.shared.Acl.AclActions
 
getSerializedSize() - Method in class alluxio.proto.shared.Acl.AclEntry
 
getSerializedSize() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
getSeries() - Method in class alluxio.job.util.TimeSeries
 
getServer() - Method in class alluxio.web.WebServer
 
getServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddress() - Method in interface alluxio.grpc.AddQuorumServerRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddress() - Method in class alluxio.grpc.GrpcChannelKey
 
getServerAddress() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddress() - Method in class alluxio.grpc.QuorumServerInfo
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddress() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddress() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddress() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressBuilder() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressBuilder() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressOrBuilder() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressOrBuilder() - Method in class alluxio.grpc.AddQuorumServerRequest
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressOrBuilder() - Method in interface alluxio.grpc.AddQuorumServerRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressOrBuilder() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressOrBuilder() - Method in class alluxio.grpc.QuorumServerInfo
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressOrBuilder() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 1;
getServerAddressOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressOrBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressOrBuilder() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressOrBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerAddressOrBuilder() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 2;
getServerChannelClass(ChannelType, boolean) - Static method in class alluxio.util.network.NettyUtils
Returns the correct ServerSocketChannel class for use by the worker.
getServerChannelClass(boolean, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Returns the correct ServerSocketChannel class for use by the worker.
getServerConnector() - Method in class alluxio.web.WebServer
 
getServerHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets list of masters/workers in conf directory.
getServerInfo(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfo(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfo(int) - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoBuilderList() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoCount() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoCount() - Method in class alluxio.grpc.GetQuorumInfoPResponse
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoCount() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoList() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoList() - Method in class alluxio.grpc.GetQuorumInfoPResponse
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoList() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoOrBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoOrBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoOrBuilder(int) - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoOrBuilderList() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoOrBuilderList() - Method in class alluxio.grpc.GetQuorumInfoPResponse
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServerInfoOrBuilderList() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
getServers() - Method in class alluxio.Registry
 
getServerSSLContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getServerSSLContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getServerState() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
getServerState() - Method in class alluxio.grpc.QuorumServerInfo
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
getServerState() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
getServiceDefinition() - Method in class alluxio.grpc.GrpcService
 
getServiceDescriptor() - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.MessagingServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
 
getServiceDescriptor() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getServiceEntityName() - Method in class alluxio.membership.DefaultServiceEntity
Get service entity name.
getServiceName() - Method in class alluxio.AbstractClient
 
getServiceName() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getServiceName() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getServiceName() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getServiceName() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
getServiceName() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
getServiceName() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
getServiceName() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
 
getServiceName() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getServiceName() - Method in class alluxio.master.file.FileSystemMasterClient
 
getServiceName() - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
 
getServiceName() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
 
getServiceName() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
 
getServiceName() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
getServiceName() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
 
getServiceName() - Method in class alluxio.security.CurrentUser
 
getServiceName() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets service name.
getServiceName() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets service name.
getServiceName() - Method in class alluxio.worker.block.BlockMasterClient
 
getServiceName() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getServiceName() - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
 
getServices() - Method in class alluxio.master.block.DefaultBlockMaster
 
getServices() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getServices() - Method in class alluxio.master.job.JobMaster
 
getServices() - Method in class alluxio.master.journal.DefaultJournalMaster
 
getServices() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getServices() - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
getServices() - Method in class alluxio.master.NoopMaster
 
getServices() - Method in interface alluxio.Server
 
getServices() - Method in class alluxio.worker.dora.PagedDoraWorker
 
getServices() - Method in class alluxio.worker.JobWorker
 
getServiceType() - Method in class alluxio.common.RpcPortHealthCheckClient
 
getServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
getServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
getServiceType() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
getServiceVersion() - Method in class alluxio.AbstractClient
 
getServiceVersion() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getServiceVersion() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getServiceVersion() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
getServiceVersion() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
getServiceVersion() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
getServiceVersion() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
getServiceVersion() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
 
getServiceVersion() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getServiceVersion(GetServiceVersionPRequest, StreamObserver<GetServiceVersionPResponse>) - Method in interface alluxio.grpc.ServiceVersionClientServiceGrpc.AsyncService
Returns the version of the master service.
getServiceVersion(GetServiceVersionPRequest) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceBlockingStub
Returns the version of the master service.
getServiceVersion(GetServiceVersionPRequest) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceFutureStub
Returns the version of the master service.
getServiceVersion(GetServiceVersionPRequest, StreamObserver<GetServiceVersionPResponse>) - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceStub
Returns the version of the master service.
getServiceVersion(GetServiceVersionPRequest, StreamObserver<GetServiceVersionPResponse>) - Method in class alluxio.grpc.ServiceVersionClientServiceHandler
 
getServiceVersion() - Method in class alluxio.master.file.FileSystemMasterClient
 
getServiceVersion() - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
 
getServiceVersion() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
 
getServiceVersion() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
 
getServiceVersion() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
getServiceVersion() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
 
getServiceVersion() - Method in class alluxio.worker.block.BlockMasterClient
 
getServiceVersion() - Method in class alluxio.worker.file.FileSystemMasterClient
 
getServiceVersion() - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
 
GetServiceVersionPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.version.GetServiceVersionPRequest
GetServiceVersionPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.version.GetServiceVersionPRequest
GetServiceVersionPRequestOrBuilder - Interface in alluxio.grpc
 
GetServiceVersionPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.version.GetServiceVersionPResponse
GetServiceVersionPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.version.GetServiceVersionPResponse
GetServiceVersionPResponseOrBuilder - Interface in alluxio.grpc
 
getServletContext() - Method in class alluxio.proxy.s3.S3Handler
get ServletContext from current http conversation.
getServletRequest() - Method in class alluxio.proxy.s3.S3Handler
get HttpServletRequest of this request.
getServletResponse() - Method in class alluxio.proxy.s3.S3Handler
get HttpServletResponse of this request.
getSessionId() - Method in class alluxio.SessionInfo
 
getSessionId() - Method in class alluxio.wire.BlockReadRequest
 
getSessionId() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getSessionId() - Method in class alluxio.worker.grpc.WriteRequest
 
getSessionId() - Method in class alluxio.worker.netty.ReadRequest
 
getSessionTempBlocks(long) - Method in interface alluxio.worker.block.meta.StorageDir
Gets the temporary blocks associated with a session in this StorageDir, an empty list is returned if the session has no temporary blocks in this StorageDir.
getSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
getSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
getSetAcl() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
getSetAclBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
getSetAclMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getSetAclOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
getSetAclOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
getSetAclOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
getSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttribute() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getSetAttributeMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getSetAttributeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetAttributeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
getSetBlocks(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
Overwrite the blocks list
getSetBlocks(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
Overwrite the blocks list
getSetBlocks(int) - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
Overwrite the blocks list
getSetBlocksCount() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
Overwrite the blocks list
getSetBlocksCount() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
Overwrite the blocks list
getSetBlocksCount() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
Overwrite the blocks list
getSetBlocksList() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
Overwrite the blocks list
getSetBlocksList() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
Overwrite the blocks list
getSetBlocksList() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
Overwrite the blocks list
getSetPathConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
getSetPermissionCommand(String, String) - Static method in class alluxio.util.ShellUtils
Returns a Unix command to set permission.
getSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
getSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
getSetTaskPoolSizeCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
getSetTaskPoolSizeCommandBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
getSetTaskPoolSizeCommandOrBuilder() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
getSetTaskPoolSizeCommandOrBuilder() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
getSetTaskPoolSizeCommandOrBuilder() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
getShadowCacheByteHit() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getShadowCacheByteHit() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCacheByteHit() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCacheByteHit() - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShadowCacheByteRead() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getShadowCacheByteRead() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCacheByteRead() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCacheByteRead() - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShadowCacheBytes() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getShadowCacheBytes() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCacheBytes(CacheScope) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCacheBytes() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCacheBytes(CacheScope) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCacheBytes() - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShadowCacheBytes(CacheScope) - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShadowCachePageHit() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getShadowCachePageHit() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCachePageHit() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCachePageHit() - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShadowCachePageRead() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getShadowCachePageRead() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCachePageRead() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCachePageRead() - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShadowCachePages() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getShadowCachePages() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCachePages(CacheScope) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
getShadowCachePages() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCachePages(CacheScope) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
getShadowCachePages() - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShadowCachePages(CacheScope) - Method in interface alluxio.client.file.cache.ShadowCacheManager
 
getShared() - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool shared = 7;
getShared() - Method in class alluxio.grpc.MountPointInfo
optional bool shared = 7;
getShared() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional bool shared = 7;
getShared() - Method in class alluxio.grpc.MountPOptions.Builder
optional bool shared = 3;
getShared() - Method in class alluxio.grpc.MountPOptions
optional bool shared = 3;
getShared() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
optional bool shared = 3;
getShared() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
getShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool shared = 5;
getShared() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool shared = 5;
getShared() - Method in class alluxio.wire.MountPointInfo
 
getSharedLibraryFileName(String) - Static method in class alluxio.jnifuse.utils.Environment
 
getSharedLibraryName(String) - Static method in class alluxio.jnifuse.utils.Environment
 
getSharedLockCount() - Method in class alluxio.rocks.RocksStore
Gets the number of shared lock on the RocksStore.
getSharedWaitersAndHolders() - Method in class alluxio.master.StateLockManager
 
getShellName() - Method in class alluxio.cli.AbstractShell
 
getShellName() - Method in class alluxio.cli.bundler.CollectInfo
 
getShellName() - Method in class alluxio.cli.extensions.ExtensionsShell
 
getShellName() - Method in class alluxio.cli.fs.FileSystemShell
 
getShellName() - Method in class alluxio.cli.fsadmin.FileSystemAdminShell
 
getShouldPersistTime() - Method in class alluxio.master.file.meta.InodeFile
 
getShouldPersistTime() - Method in interface alluxio.master.file.meta.InodeFileView
 
getShouldPersistTime() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 should_persist_time = 27;
getShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 should_persist_time = 27;
getShouldPersistTime() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 should_persist_time = 27;
getShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 should_persist_time = 28;
getShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 should_persist_time = 28;
getShouldPersistTime() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 should_persist_time = 28;
getShowPermissions() - Method in class alluxio.wire.MasterWebUIBrowse
Gets show permissions.
getShowPermissions() - Method in class alluxio.wire.MasterWebUIData
Gets show permissions.
getSignature() - Method in class alluxio.s3.auth.AwsAuthInfo
 
getSignature() - Method in class alluxio.s3.signature.SignatureInfo
 
getSignedHeaders() - Method in class alluxio.s3.signature.SignatureInfo
 
getSize() - Method in class alluxio.cli.fs.command.job.JobAttempt
Get how many files contained in job attempt.
getSize() - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
getSize() - Method in class alluxio.s3.ListBucketResult.Content
 
getSize() - Method in class alluxio.util.UnixMountInfo.Options
 
getSize() - Method in class alluxio.util.webui.UIFileInfo
Gets size.
getSize() - Method in class alluxio.worker.block.AllocateOptions
 
getSizeFromBytes(long) - Static method in class alluxio.util.FormatUtils
Returns a human-readable version of bytes 10GB 2048KB etc.
getSizeInBytes() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
 
getSizeInBytes() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
getSizeInTags() - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
 
getSizeInTags() - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
getSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional bool skewed = 4;
getSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage
optional bool skewed = 4;
getSkewed() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional bool skewed = 4;
getSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest.Builder
optional bool skip_if_exists = 4;
getSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest
optional bool skip_if_exists = 4;
getSkipIfExists() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
optional bool skip_if_exists = 4;
getSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool skipIfExists = 5;
getSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions
optional bool skipIfExists = 5;
getSkipIfExists() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool skipIfExists = 5;
getSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool skip_if_exists = 10;
getSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional bool skip_if_exists = 10;
getSkipIfExists() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional bool skip_if_exists = 10;
getSleeper() - Method in class alluxio.time.TimeContext
 
getSleepTime() - Method in class alluxio.retry.ExponentialBackoffRetry
 
getSleepTime() - Method in class alluxio.retry.SleepingRetry
How long to sleep before the next retry is performed.
getSleepUnit() - Method in class alluxio.retry.SleepingRetry
Unit of time that SleepingRetry.getSleepTime() is measured in.
getSlotIndex() - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
 
getSnapshot(UfsJournal) - Static method in class alluxio.master.journal.ufs.UfsJournalSnapshot
Creates a snapshot of the journal.
getSnapshot() - Method in class alluxio.metrics.MaxReservoir
Returns a snapshot of the reservoir's values, which has the max value set as the overall max value sent as an update to this reservoir.
getSnapshotDir() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
getSnapshotIndex() - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotIndex = 2;
getSnapshotIndex() - Method in class alluxio.grpc.SnapshotData
optional int64 snapshotIndex = 2;
getSnapshotIndex() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
optional int64 snapshotIndex = 2;
getSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotIndex = 2;
getSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata
optional int64 snapshotIndex = 2;
getSnapshotIndex() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
optional int64 snapshotIndex = 2;
getSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated. 
getSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated. 
getSnapshotInfo() - Method in interface alluxio.grpc.GetSnapshotInfoRequestOrBuilder
Deprecated. 
getSnapshotInfoBuilder() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
getSnapshotInfoOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
getSnapshotInfoOrBuilder() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
getSnapshotInfoOrBuilder() - Method in interface alluxio.grpc.GetSnapshotInfoRequestOrBuilder
Deprecated.
GetSnapshotInfoRequest - Class in alluxio.grpc
Deprecated.
getSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated. 
getSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest
Deprecated. 
getSnapshotInfoRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
Deprecated. 
GetSnapshotInfoRequest.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.GetSnapshotInfoRequest
getSnapshotInfoRequestBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
GetSnapshotInfoRequestOrBuilder - Interface in alluxio.grpc
Deprecated.
getSnapshotInfoRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
getSnapshotInfoRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest
Deprecated.
getSnapshotInfoRequestOrBuilder() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
Deprecated.
GetSnapshotInfoResponse - Class in alluxio.grpc
Deprecated.
getSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated. 
getSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated. 
getSnapshotInfoResponse() - Method in interface alluxio.grpc.JournalQueryResponseOrBuilder
Deprecated. 
GetSnapshotInfoResponse.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.GetSnapshotInfoResponse
getSnapshotInfoResponseBuilder() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
GetSnapshotInfoResponseOrBuilder - Interface in alluxio.grpc
Deprecated.
getSnapshotInfoResponseOrBuilder() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
getSnapshotInfoResponseOrBuilder() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
getSnapshotInfoResponseOrBuilder() - Method in interface alluxio.grpc.JournalQueryResponseOrBuilder
Deprecated.
GetSnapshotRequest - Class in alluxio.grpc
Deprecated.
getSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated. 
getSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest
Deprecated. 
getSnapshotRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
Deprecated. 
GetSnapshotRequest.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.GetSnapshotRequest
getSnapshotRequestBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
GetSnapshotRequestOrBuilder - Interface in alluxio.grpc
Deprecated.
getSnapshotRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
getSnapshotRequestOrBuilder() - Method in class alluxio.grpc.JournalQueryRequest
Deprecated.
getSnapshotRequestOrBuilder() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
Deprecated.
getSnapshotTerm() - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotTerm = 1;
getSnapshotTerm() - Method in class alluxio.grpc.SnapshotData
optional int64 snapshotTerm = 1;
getSnapshotTerm() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
optional int64 snapshotTerm = 1;
getSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotTerm = 1;
getSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata
optional int64 snapshotTerm = 1;
getSnapshotTerm() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
optional int64 snapshotTerm = 1;
getSocketAddress() - Method in class alluxio.grpc.GrpcServerAddress
 
getSortedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedBy(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByBuilder(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByBuilderList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByList() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByOrBuilder(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByOrBuilder(int) - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByOrBuilderList() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSortedByOrBuilderList() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
getSource(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
 
getSource(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
getSource(PropertyKey) - Static method in class alluxio.conf.Configuration
 
getSource(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getSource() - Method in class alluxio.grpc.ClientMetrics.Builder
optional string source = 1;
getSource() - Method in class alluxio.grpc.ClientMetrics
optional string source = 1;
getSource() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
optional string source = 1;
getSource() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string source = 2;
getSource() - Method in class alluxio.grpc.ConfigProperty
optional string source = 2;
getSource() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string source = 2;
getSource() - Method in class alluxio.grpc.Metric.Builder
optional string source = 2;
getSource() - Method in class alluxio.grpc.Metric
optional string source = 2;
getSource() - Method in interface alluxio.grpc.MetricOrBuilder
optional string source = 2;
getSource() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getSource() - Method in class alluxio.job.plan.migrate.MigrateCommand
 
getSource() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
getSource() - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
getSource() - Method in class alluxio.metrics.Metric
 
getSource(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getSource() - Method in class alluxio.wire.Property
 
getSourceBytes() - Method in class alluxio.grpc.ClientMetrics.Builder
optional string source = 1;
getSourceBytes() - Method in class alluxio.grpc.ClientMetrics
optional string source = 1;
getSourceBytes() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
optional string source = 1;
getSourceBytes() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string source = 2;
getSourceBytes() - Method in class alluxio.grpc.ConfigProperty
optional string source = 2;
getSourceBytes() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string source = 2;
getSourceBytes() - Method in class alluxio.grpc.Metric.Builder
optional string source = 2;
getSourceBytes() - Method in class alluxio.grpc.Metric
optional string source = 2;
getSourceBytes() - Method in interface alluxio.grpc.MetricOrBuilder
optional string source = 2;
getSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in class alluxio.grpc.CacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in class alluxio.grpc.CacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in interface alluxio.grpc.CacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHost() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in class alluxio.grpc.AsyncCacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in class alluxio.grpc.CacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in class alluxio.grpc.CacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in interface alluxio.grpc.CacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourceHostBytes() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
getSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int32 source_port = 3;
getSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest
optional int32 source_port = 3;
getSourcePort() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional int32 source_port = 3;
getSourcePort() - Method in class alluxio.grpc.CacheRequest.Builder
optional int32 source_port = 3;
getSourcePort() - Method in class alluxio.grpc.CacheRequest
optional int32 source_port = 3;
getSourcePort() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional int32 source_port = 3;
getSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
getSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int32 source_port = 3;
getSourcePort() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int32 source_port = 3;
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in interface alluxio.underfs.UnderFileSystem
Queries the under file system about the space of the indicated path (e.g., space left, space used and etc).
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 space_to_reserve = 10;
getSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand
optional int64 space_to_reserve = 10;
getSpaceToReserve() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional int64 space_to_reserve = 10;
getSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
getSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 space_to_reserve = 4;
getSpaceToReserve() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 space_to_reserve = 4;
getSpec() - Method in class alluxio.grpc.table.LayoutSpec.Builder
optional string spec = 1;
getSpec() - Method in class alluxio.grpc.table.LayoutSpec
optional string spec = 1;
getSpec() - Method in interface alluxio.grpc.table.LayoutSpecOrBuilder
optional string spec = 1;
getSpec() - Method in class alluxio.grpc.table.PartitionSpec.Builder
optional string spec = 1;
getSpec() - Method in class alluxio.grpc.table.PartitionSpec
optional string spec = 1;
getSpec() - Method in interface alluxio.grpc.table.PartitionSpecOrBuilder
optional string spec = 1;
getSpecBytes() - Method in class alluxio.grpc.table.LayoutSpec.Builder
optional string spec = 1;
getSpecBytes() - Method in class alluxio.grpc.table.LayoutSpec
optional string spec = 1;
getSpecBytes() - Method in interface alluxio.grpc.table.LayoutSpecOrBuilder
optional string spec = 1;
getSpecBytes() - Method in class alluxio.grpc.table.PartitionSpec.Builder
optional string spec = 1;
getSpecBytes() - Method in class alluxio.grpc.table.PartitionSpec
optional string spec = 1;
getSpecBytes() - Method in interface alluxio.grpc.table.PartitionSpecOrBuilder
optional string spec = 1;
getSrc() - Method in class alluxio.grpc.Route.Builder
required string src = 1;
getSrc() - Method in class alluxio.grpc.Route
required string src = 1;
getSrc() - Method in interface alluxio.grpc.RouteOrBuilder
required string src = 1;
getSrc() - Method in class alluxio.job.CopyJobRequest
 
getSrc() - Method in class alluxio.job.MoveJobRequest
 
getSrc() - Method in class alluxio.master.job.CopyJob
 
getSrc() - Method in class alluxio.master.job.MoveJob
 
getSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string src = 1;
getSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string src = 1;
getSrc() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string src = 1;
getSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string src = 1;
getSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string src = 1;
getSrc() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string src = 1;
getSrcBytes() - Method in class alluxio.grpc.Route.Builder
required string src = 1;
getSrcBytes() - Method in class alluxio.grpc.Route
required string src = 1;
getSrcBytes() - Method in interface alluxio.grpc.RouteOrBuilder
required string src = 1;
getSrcBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string src = 1;
getSrcBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string src = 1;
getSrcBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string src = 1;
getSrcBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string src = 1;
getSrcBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string src = 1;
getSrcBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string src = 1;
getSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string srcPath = 2;
getSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions
optional string srcPath = 2;
getSrcPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string srcPath = 2;
getSrcPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string srcPath = 2;
getSrcPathBytes() - Method in class alluxio.grpc.AddPolicyPOptions
optional string srcPath = 2;
getSrcPathBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string srcPath = 2;
getStandbyMasterInfos() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getStandbyMasterInfos() - Method in interface alluxio.master.meta.MetaMaster
 
getStandbyMasterInfos() - Method in class alluxio.wire.MasterWebUIMasters
Get info of standby masters.
getStandbyServices() - Method in class alluxio.master.block.DefaultBlockMaster
 
getStandbyServices() - Method in interface alluxio.master.Master
 
getStandbyServices() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getStart() - Method in class alluxio.wire.BlockReadRequest
 
getStart() - Method in class alluxio.worker.netty.ReadRequest
 
getStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start the listing after this path.
getStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions
Start the listing after this path.
getStartAfter() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Start the listing after this path.
getStartAfter() - Method in class alluxio.s3.ListBucketOptions
 
getStartAfter() - Method in class alluxio.s3.ListBucketResult
 
getStartAfterBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start the listing after this path.
getStartAfterBytes() - Method in class alluxio.grpc.ListStatusPartialPOptions
Start the listing after this path.
getStartAfterBytes() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Start the listing after this path.
getStartDelayMs() - Method in class alluxio.stress.job.StressBenchConfig
 
getStartFrom() - Method in class alluxio.master.metastore.ReadOption
 
getStartMs() - Method in class alluxio.master.predicate.interval.Interval
 
getStartTime() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get started time.
getStartTime() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional int64 startTime = 3;
getStartTime() - Method in class alluxio.grpc.JobMasterStatus
optional int64 startTime = 3;
getStartTime() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional int64 startTime = 3;
getStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional int64 startTime = 2;
getStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional int64 startTime = 2;
getStartTime() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional int64 startTime = 2;
getStartTime() - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 startTime = 3;
getStartTime() - Method in class alluxio.grpc.ProxyStatus
optional int64 startTime = 3;
getStartTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional int64 startTime = 3;
getStartTime() - Method in class alluxio.job.MasterWorkerInfo
 
getStartTime() - Method in class alluxio.master.block.meta.MasterWorkerInfo
No locking required.
getStartTime() - Method in class alluxio.util.webui.UIWorkerInfo
Gets start time.
getStartTime() - Method in class alluxio.wire.MasterInfo
 
getStartTime() - Method in class alluxio.wire.MasterWebUIOverview
Gets start time.
getStartTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 startTimeMs = 5;
getStartTimeMs() - Method in class alluxio.grpc.MasterInfo
optional int64 startTimeMs = 5;
getStartTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int64 startTimeMs = 5;
getStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 startTimeMs = 2;
getStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
optional int64 startTimeMs = 2;
getStartTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
optional int64 startTimeMs = 2;
getStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 startTimeMs = 2;
getStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
optional int64 startTimeMs = 2;
getStartTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional int64 startTimeMs = 2;
getStartTimeMs() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 startTimeMs = 7;
getStartTimeMs() - Method in class alluxio.grpc.WorkerInfo
optional int64 startTimeMs = 7;
getStartTimeMs() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 startTimeMs = 7;
getStartTimeMs() - Method in class alluxio.master.CoreMasterContext
 
getStartTimeMs() - Method in class alluxio.master.MasterProcess
 
getStartTimeMs() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getStartTimeMs() - Method in class alluxio.master.meta.JobMasterInfo
 
getStartTimeMs() - Method in class alluxio.master.meta.MasterInfo
 
getStartTimeMs() - Method in interface alluxio.master.meta.MetaMaster
 
getStartTimeMs() - Method in class alluxio.master.meta.ProxyInfo
 
getStartTimeMs() - Method in class alluxio.proxy.AlluxioProxyProcess
 
getStartTimeMs() - Method in interface alluxio.proxy.ProxyProcess
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getStartTimeMs() - Method in class alluxio.wire.WorkerInfo
 
getStartTimeMs() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
getStartTimeMs() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getStartTimeMs() - Method in interface alluxio.worker.JobWorkerProcess
 
getStartTimeMs() - Method in interface alluxio.worker.WorkerProcess
 
getState() - Method in class alluxio.cli.ValidationTaskResult
 
getState() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional string state = 1;
getState() - Method in class alluxio.grpc.JobMasterStatus
optional string state = 1;
getState() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional string state = 1;
getState() - Method in class alluxio.grpc.MasterVersion.Builder
optional string state = 3;
getState() - Method in class alluxio.grpc.MasterVersion
optional string state = 3;
getState() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional string state = 3;
getState() - Method in class alluxio.grpc.ProxyStatus.Builder
optional string state = 2;
getState() - Method in class alluxio.grpc.ProxyStatus
optional string state = 2;
getState() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional string state = 2;
getState() - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
getState() - Method in class alluxio.grpc.WorkerInfo
optional string state = 4;
getState() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional string state = 4;
getState() - Method in class alluxio.master.AbstractPrimarySelector
 
getState() - Method in class alluxio.master.AlwaysStandbyPrimarySelector
 
getState() - Method in interface alluxio.master.PrimarySelector
 
getState() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
getState() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required .alluxio.proto.journal.PJobState state = 3;
getState() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required .alluxio.proto.journal.PJobState state = 3;
getState() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 2;
getState() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required .alluxio.proto.journal.PJobState state = 2;
getState() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required .alluxio.proto.journal.PJobState state = 2;
getState() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
getState() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required .alluxio.proto.journal.PJobState state = 3;
getState() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required .alluxio.proto.journal.PJobState state = 3;
getState() - Method in class alluxio.util.webui.NodeInfo
Gets state.
getState() - Method in class alluxio.wire.BackupStatus
 
getState() - Method in class alluxio.wire.WorkerInfo
 
getStateBytes() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional string state = 1;
getStateBytes() - Method in class alluxio.grpc.JobMasterStatus
optional string state = 1;
getStateBytes() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional string state = 1;
getStateBytes() - Method in class alluxio.grpc.MasterVersion.Builder
optional string state = 3;
getStateBytes() - Method in class alluxio.grpc.MasterVersion
optional string state = 3;
getStateBytes() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional string state = 3;
getStateBytes() - Method in class alluxio.grpc.ProxyStatus.Builder
optional string state = 2;
getStateBytes() - Method in class alluxio.grpc.ProxyStatus
optional string state = 2;
getStateBytes() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional string state = 2;
getStateBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
getStateBytes() - Method in class alluxio.grpc.WorkerInfo
optional string state = 4;
getStateBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional string state = 4;
getStateLockHolders() - Method in interface alluxio.client.file.FileSystemMasterClient
 
getStateLockHolders() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getStateLockHolders(GetStateLockHoldersPRequest, StreamObserver<GetStateLockHoldersPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
 
getStateLockHolders(GetStateLockHoldersPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
 
getStateLockHolders(GetStateLockHoldersPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
 
getStateLockHolders(GetStateLockHoldersPRequest, StreamObserver<GetStateLockHoldersPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
 
getStateLockHolders(GetStateLockHoldersPRequest, StreamObserver<GetStateLockHoldersPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
GetStateLockHoldersPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStateLockHoldersPOptions
GetStateLockHoldersPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStateLockHoldersPOptions
GetStateLockHoldersPOptionsOrBuilder - Interface in alluxio.grpc
 
GetStateLockHoldersPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStateLockHoldersPRequest
GetStateLockHoldersPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStateLockHoldersPRequest
GetStateLockHoldersPRequestOrBuilder - Interface in alluxio.grpc
 
GetStateLockHoldersPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStateLockHoldersPResponse
GetStateLockHoldersPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStateLockHoldersPResponse
GetStateLockHoldersPResponseOrBuilder - Interface in alluxio.grpc
 
getStateLockManager() - Method in class alluxio.master.MasterContext
 
getStateLockSharedWaitersAndHolders() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getStateLockSharedWaitersAndHolders() - Method in interface alluxio.master.file.FileSystemMaster
 
getStateMachine() - Method in class alluxio.master.journal.raft.RaftJournal
 
getStateMachineStorage() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
getStateUnsafe() - Method in class alluxio.master.AbstractPrimarySelector
 
getStateUnsafe() - Method in class alluxio.master.AlwaysStandbyPrimarySelector
 
getStateUnsafe() - Method in interface alluxio.master.PrimarySelector
 
getStatistics(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatistics(int) - Method in class alluxio.grpc.table.ColumnStatisticsList
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatistics(int) - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatistics(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatistics(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatistics(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsBuilder(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsBuilder(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsBuilderList() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsBuilderList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsCount() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsCount() - Method in class alluxio.grpc.table.ColumnStatisticsList
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsCount() - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsCount() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsCount() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsList() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsList() - Method in class alluxio.grpc.table.ColumnStatisticsList
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsList() - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsList() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.ColumnStatisticsList
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilder(int) - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilder(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilder(int) - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.ColumnStatisticsList
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilderList() - Method in interface alluxio.grpc.table.ColumnStatisticsListOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilderList() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStatisticsOrBuilderList() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPResponseOrBuilder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
getStats() - Method in class alluxio.grpc.table.Layout.Builder
Deprecated.
getStats() - Method in class alluxio.grpc.table.Layout
Deprecated.
getStats() - Method in interface alluxio.grpc.table.LayoutOrBuilder
Deprecated.
getStatsCount() - Method in class alluxio.grpc.table.Layout.Builder
 
getStatsCount() - Method in class alluxio.grpc.table.Layout
 
getStatsCount() - Method in interface alluxio.grpc.table.LayoutOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsMap() - Method in class alluxio.grpc.table.Layout.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsMap() - Method in class alluxio.grpc.table.Layout
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsMap() - Method in interface alluxio.grpc.table.LayoutOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.Layout.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsOrDefault(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.Layout
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsOrDefault(String, ColumnStatisticsInfo) - Method in interface alluxio.grpc.table.LayoutOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsOrThrow(String) - Method in class alluxio.grpc.table.Layout.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsOrThrow(String) - Method in class alluxio.grpc.table.Layout
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatsOrThrow(String) - Method in interface alluxio.grpc.table.LayoutOrBuilder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
getStatus(GetStatusPRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
get file status.
getStatus(GetStatusPRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
getStatus() - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
 
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
getStatus(String, GetStatusPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Get status.
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
getStatus(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.getStatus(AlluxioURI, GetStatusPOptions) with default options.
getStatus(AlluxioURI, GetStatusPOptions) - Method in interface alluxio.client.file.FileSystem
Gets the URIStatus object that represents the metadata of an Alluxio path.
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
getStatus(AlluxioURI, GetStatusPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
 
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
getStatus() - Method in class alluxio.client.file.options.InStreamOptions
 
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
getStatus(AlluxioURI) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getStatus(AlluxioURI, GetStatusPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getStatus(String, GetStatusOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getStatus() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
getStatus() - Method in exception alluxio.exception.status.AlluxioStatusException
 
getStatus(int, long) - Method in class alluxio.fsmaster.FileSystemMasterBase
 
getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Returns the status of the file or directory.
getStatus(GetStatusPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Returns the status of the file or directory.
getStatus(GetStatusPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Returns the status of the file or directory.
getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Returns the status of the file or directory.
getStatus() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.Status status = 4;
getStatus() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.Status status = 4;
getStatus() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.Status status = 4;
getStatus() - Method in class alluxio.grpc.ConfigCheckReport.Builder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
getStatus() - Method in class alluxio.grpc.ConfigCheckReport
optional .alluxio.grpc.meta.ConfigStatus status = 3;
getStatus() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
getStatus() - Method in class alluxio.grpc.CopyResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in class alluxio.grpc.CopyResponse
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in interface alluxio.grpc.CopyResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Returns the status of the file or directory.
getStatus(GetStatusPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Returns the status of the file or directory.
getStatus(GetStatusPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Returns the status of the file or directory.
getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Returns the status of the file or directory.
getStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
getStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse
optional .alluxio.grpc.policy.PolicyStatus status = 1;
getStatus() - Method in interface alluxio.grpc.GetPolicyStatusPResponseOrBuilder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
getStatus() - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.Status status = 4;
getStatus() - Method in class alluxio.grpc.JobInfo
optional .alluxio.grpc.job.Status status = 4;
getStatus() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional .alluxio.grpc.job.Status status = 4;
getStatus() - Method in class alluxio.grpc.JobProgress.Builder
optional .alluxio.grpc.job.Status status = 7;
getStatus() - Method in class alluxio.grpc.JobProgress
optional .alluxio.grpc.job.Status status = 7;
getStatus() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional .alluxio.grpc.job.Status status = 7;
getStatus(int) - Method in class alluxio.grpc.ListAllPOptions.Builder
repeated .alluxio.grpc.job.Status status = 1;
getStatus(int) - Method in class alluxio.grpc.ListAllPOptions
repeated .alluxio.grpc.job.Status status = 1;
getStatus(int) - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
repeated .alluxio.grpc.job.Status status = 1;
getStatus() - Method in class alluxio.grpc.LoadFileResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in class alluxio.grpc.LoadFileResponse
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in class alluxio.grpc.LoadResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in class alluxio.grpc.LoadResponse
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in interface alluxio.grpc.LoadResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in class alluxio.grpc.MoveResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in class alluxio.grpc.MoveResponse
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in interface alluxio.grpc.MoveResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
getStatus() - Method in class alluxio.grpc.StatusSummary.Builder
optional .alluxio.grpc.job.Status status = 1;
getStatus() - Method in class alluxio.grpc.StatusSummary
optional .alluxio.grpc.job.Status status = 1;
getStatus() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
optional .alluxio.grpc.job.Status status = 1;
getStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
getStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse
optional .alluxio.grpc.table.SyncStatus status = 2;
getStatus() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
optional .alluxio.grpc.table.SyncStatus status = 2;
getStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
Deprecated.
getStatus() - Method in class alluxio.grpc.UpdateConfigurationPResponse
Deprecated.
getStatus() - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
Deprecated.
getStatus() - Method in class alluxio.heartbeat.HeartbeatThread
 
getStatus() - Method in class alluxio.job.plan.meta.PlanInfo
 
getStatus() - Method in interface alluxio.job.wire.JobInfo
 
getStatus() - Method in class alluxio.job.wire.PlanInfo
 
getStatus() - Method in class alluxio.job.wire.SimpleJobStatusBlock
Get status of the job.
getStatus() - Method in class alluxio.job.wire.StatusSummary
Returns the Status this object represents.
getStatus() - Method in class alluxio.job.wire.TaskInfo
 
getStatus() - Method in class alluxio.job.wire.WorkflowInfo
 
getStatus() - Method in class alluxio.job.workflow.WorkflowExecution
 
getStatus(UUID) - Method in class alluxio.master.backup.BackupTracker
 
getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
getStatus(long) - Method in class alluxio.master.job.JobMaster
Gets information of the given job id (verbose = True).
getStatus(long, boolean) - Method in class alluxio.master.job.JobMaster
Gets information of the given job id.
getStatus(long) - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
Gets the job status.
getStatus(long, boolean) - Method in class alluxio.master.job.workflow.WorkflowTracker
Gets information of the given job id.
getStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
getStatus() - Method in class alluxio.proto.dataserver.Protocol.Response
optional .alluxio.proto.status.PStatus status = 1;
getStatus() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional .alluxio.proto.status.PStatus status = 1;
getStatus(String, GetStatusPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
getStatus() - Method in class alluxio.s3.S3ErrorCode
 
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
 
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
 
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getStatus(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getStatus(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
Get the UfsStatus from a given AlluxioURI.
getStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file or directory status.
getStatus(String, GetStatusOptions) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file or directory status.
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getStatus(String, GetStatusOptions) - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getStatus(GetStatusPRequest, StreamObserver<GetStatusPResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
getStatusBench(FileSystemMasterBench.FileSystem, FileSystemMasterBench.ThreadState) - Method in class alluxio.fsmaster.FileSystemMasterBench
 
getStatusBuilder() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
getStatusBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
getStatusByGrpc(String, GetStatusPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
 
getStatusCode() - Method in exception alluxio.exception.status.AlluxioStatusException
 
getStatusCode() - Method in class alluxio.RestUtils.ErrorResponse
Gets status.
GetStatusContext - Class in alluxio.master.file.contexts
Used to merge and wrap GetStatusPOptions.
getStatusCount() - Method in class alluxio.grpc.ListAllPOptions.Builder
repeated .alluxio.grpc.job.Status status = 1;
getStatusCount() - Method in class alluxio.grpc.ListAllPOptions
repeated .alluxio.grpc.job.Status status = 1;
getStatusCount() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
repeated .alluxio.grpc.job.Status status = 1;
getStatusCount() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
getStatusCount() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
getStatusCount() - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
map<string, bool> status = 1;
getStatusDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
getStatusList() - Method in class alluxio.grpc.ListAllPOptions.Builder
repeated .alluxio.grpc.job.Status status = 1;
getStatusList() - Method in class alluxio.grpc.ListAllPOptions
repeated .alluxio.grpc.job.Status status = 1;
getStatusList() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
repeated .alluxio.grpc.job.Status status = 1;
getStatusMap() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
map<string, bool> status = 1;
getStatusMap() - Method in class alluxio.grpc.UpdateConfigurationPResponse
map<string, bool> status = 1;
getStatusMap() - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
map<string, bool> status = 1;
GetStatusOptions - Class in alluxio.underfs.options
Method options for getting the status of a file in UnderFileSystem.
GetStatusOptions() - Constructor for class alluxio.underfs.options.GetStatusOptions
 
getStatusOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
getStatusOrBuilder() - Method in class alluxio.grpc.GetPolicyStatusPResponse
optional .alluxio.grpc.policy.PolicyStatus status = 1;
getStatusOrBuilder() - Method in interface alluxio.grpc.GetPolicyStatusPResponseOrBuilder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
getStatusOrBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
getStatusOrBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse
optional .alluxio.grpc.table.SyncStatus status = 2;
getStatusOrBuilder() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
optional .alluxio.grpc.table.SyncStatus status = 2;
getStatusOrDefault(String, boolean) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
map<string, bool> status = 1;
getStatusOrDefault(String, boolean) - Method in class alluxio.grpc.UpdateConfigurationPResponse
map<string, bool> status = 1;
getStatusOrDefault(String, boolean) - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
map<string, bool> status = 1;
getStatusOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
map<string, bool> status = 1;
getStatusOrThrow(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse
map<string, bool> status = 1;
getStatusOrThrow(String) - Method in interface alluxio.grpc.UpdateConfigurationPResponseOrBuilder
map<string, bool> status = 1;
GetStatusPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStatusPOptions
GetStatusPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStatusPOptions
GetStatusPOptionsOrBuilder - Interface in alluxio.grpc
 
GetStatusPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStatusPRequest
GetStatusPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStatusPRequest
GetStatusPRequestOrBuilder - Interface in alluxio.grpc
 
GetStatusPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStatusPResponse
GetStatusPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetStatusPResponse
GetStatusPResponseOrBuilder - Interface in alluxio.grpc
 
getStatusSummary() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Get status summary.
getStealCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the total number of tasks stolen from one thread's work queue by another.
getStopJobMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getStopwatch() - Method in class alluxio.proxy.s3.S3Handler
Get Stopwatch object used for recording this request's latency.
getStopwatch() - Method in class alluxio.worker.s3.S3NettyHandler
Get Stopwatch object used for recording this request's latency.
getStorage(int) - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
getStorage(int) - Method in class alluxio.grpc.StorageList
a lost storage path
getStorage(int) - Method in interface alluxio.grpc.StorageListOrBuilder
a lost storage path
getStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
getStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional .alluxio.grpc.table.layout.Storage storage = 5;
getStorage() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional .alluxio.grpc.table.layout.Storage storage = 5;
getStorageBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
getStorageBytes(int) - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
getStorageBytes(int) - Method in class alluxio.grpc.StorageList
a lost storage path
getStorageBytes(int) - Method in interface alluxio.grpc.StorageListOrBuilder
a lost storage path
getStorageClass() - Method in class alluxio.proxy.s3.ListPartsResult
 
getStorageCount() - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
getStorageCount() - Method in class alluxio.grpc.StorageList
a lost storage path
getStorageCount() - Method in interface alluxio.grpc.StorageListOrBuilder
a lost storage path
getStorageDirs() - Method in class alluxio.wire.WorkerWebUIOverview
Gets storage dirs.
getStorageDirs() - Method in interface alluxio.worker.block.meta.StorageTier
 
getStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
getStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
getStorageFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
getStorageFormatBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
getStorageFormatOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
getStorageFormatOrBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
getStorageFormatOrBuilder() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
getStorageList() - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
getStorageList() - Method in class alluxio.grpc.StorageList
a lost storage path
getStorageList() - Method in interface alluxio.grpc.StorageListOrBuilder
a lost storage path
getStorageOrBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
getStorageOrBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional .alluxio.grpc.table.layout.Storage storage = 5;
getStorageOrBuilder() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional .alluxio.grpc.table.layout.Storage storage = 5;
getStorageTierAlias() - Method in class alluxio.util.webui.StorageTierInfo
Gets storage tier alias.
getStorageTierAssoc() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getStorageTierInfos() - Method in class alluxio.wire.MasterWebUIOverview
Gets storage tier infos.
getStorageTiers(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
getStorageTiers(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
the list of storage tiers
getStorageTiers(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the list of storage tiers
getStorageTiersBytes(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
getStorageTiersBytes(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
the list of storage tiers
getStorageTiersBytes(int) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the list of storage tiers
getStorageTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
getStorageTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
the list of storage tiers
getStorageTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the list of storage tiers
getStorageTiersList() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
getStorageTiersList() - Method in class alluxio.grpc.RegisterWorkerPRequest
the list of storage tiers
getStorageTiersList() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the list of storage tiers
getStoreDirOfFile(String) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
getStoreDirOfFile(String) - Method in interface alluxio.client.file.cache.PageMetaStore
Gets the store dir which the specified file is assigned to be cached in.
getStoreDirs() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
getStoreDirs() - Method in interface alluxio.client.file.cache.PageMetaStore
Gets the storage directories.
getStoreMeta() - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata for the entire block store.
getStoreMetaFull() - Method in interface alluxio.worker.block.BlockWorker
Similar as BlockWorker.getStoreMeta() except that this also contains full blockId list.
getStream() - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader.Entry
Return a checkpoint stream containing the bytes for this checkpoint.
getStreamingUploadEnabled() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getString(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the String value for the given key.
getString(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the String value for the given key.
getString(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getString(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsOrBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringStatsOrBuilder() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
getStringTosSign() - Method in class alluxio.s3.auth.AwsAuthInfo
 
getStringType() - Method in class alluxio.grpc.table.Value.Builder
string string_type = 3;
getStringType() - Method in class alluxio.grpc.table.Value
string string_type = 3;
getStringType() - Method in interface alluxio.grpc.table.ValueOrBuilder
string string_type = 3;
getStringTypeBytes() - Method in class alluxio.grpc.table.Value.Builder
string string_type = 3;
getStringTypeBytes() - Method in class alluxio.grpc.table.Value
string string_type = 3;
getStringTypeBytes() - Method in interface alluxio.grpc.table.ValueOrBuilder
string string_type = 3;
getStringValue() - Method in class alluxio.grpc.MetricValue.Builder
optional string stringValue = 2;
getStringValue() - Method in class alluxio.grpc.MetricValue
optional string stringValue = 2;
getStringValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
optional string stringValue = 2;
getStringValueBytes() - Method in class alluxio.grpc.MetricValue.Builder
optional string stringValue = 2;
getStringValueBytes() - Method in class alluxio.grpc.MetricValue
optional string stringValue = 2;
getStringValueBytes() - Method in interface alluxio.grpc.MetricValueOrBuilder
optional string stringValue = 2;
getSubCommands() - Method in interface alluxio.cli.Command
 
getSubCommands() - Method in class alluxio.cli.command.MetadataCacheCommand
 
getSubCommands() - Method in class alluxio.cli.fsadmin.command.JournalCommand
 
getSubCommands() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
 
getSubCommands() - Method in class alluxio.cli.fsadmin.command.NodesCommand
 
getSubCommands() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
 
getSubject() - Method in class alluxio.ClientContext
 
getSubject() - Method in class alluxio.grpc.PAclEntry.Builder
optional string subject = 2;
getSubject() - Method in class alluxio.grpc.PAclEntry
optional string subject = 2;
getSubject() - Method in interface alluxio.grpc.PAclEntryOrBuilder
optional string subject = 2;
getSubject() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional string subject = 2;
getSubject() - Method in class alluxio.proto.shared.Acl.AclEntry
optional string subject = 2;
getSubject() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
optional string subject = 2;
getSubject() - Method in class alluxio.security.authorization.AclEntry
 
getSubject() - Method in class alluxio.security.user.BaseUserState
 
getSubject() - Method in interface alluxio.security.user.UserState
Returns the Subject for this user.
getSubjectBytes() - Method in class alluxio.grpc.PAclEntry.Builder
optional string subject = 2;
getSubjectBytes() - Method in class alluxio.grpc.PAclEntry
optional string subject = 2;
getSubjectBytes() - Method in interface alluxio.grpc.PAclEntryOrBuilder
optional string subject = 2;
getSubjectBytes() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional string subject = 2;
getSubjectBytes() - Method in class alluxio.proto.shared.Acl.AclEntry
optional string subject = 2;
getSubjectBytes() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
optional string subject = 2;
getSubmissionTime() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 submissionTime = 5;
getSubmissionTime() - Method in class alluxio.grpc.CmdSummary
optional int64 submissionTime = 5;
getSubmissionTime() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional int64 submissionTime = 5;
getSubmitJobMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getSubmitMethod() - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
getSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
TODO(gpang): remove in favor of status
getSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse
TODO(gpang): remove in favor of status
getSuccess() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
TODO(gpang): remove in favor of status
getSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
optional bool success = 1;
getSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse
optional bool success = 1;
getSuccess() - Method in interface alluxio.grpc.table.DetachDatabasePResponseOrBuilder
optional bool success = 1;
getSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
TODO(gpang): remove in favor of status
getSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse
TODO(gpang): remove in favor of status
getSuccess() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
TODO(gpang): remove in favor of status
getSummary() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
getSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
getSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
getSummary() - Method in interface alluxio.grpc.GetJobServiceSummaryPResponseOrBuilder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
getSummary() - Method in class alluxio.job.util.TimeSeries
 
getSummary() - Method in class alluxio.master.job.JobMaster
Gets summary of the job service.
getSummaryBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
getSummaryOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
getSummaryOrBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
getSummaryOrBuilder() - Method in interface alluxio.grpc.GetJobServiceSummaryPResponseOrBuilder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
getSummaryPerStatus(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatus(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatus(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatus() - Method in class alluxio.job.wire.JobServiceSummary
Returns an unmodifiable collection of summary per job status.
getSummaryPerStatusBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusCount() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusCount() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusCount() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusOrBuilder(int) - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusOrBuilder(int) - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusOrBuilderList() - Method in class alluxio.grpc.JobServiceSummary
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSummaryPerStatusOrBuilderList() - Method in interface alluxio.grpc.JobServiceSummaryOrBuilder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
getSuperclassFieldPadding() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the quantum field size for a field owned by one of an object's ancestor superclasses in this JVM.
getSupportedVersions(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Get a list of supported versions for a particular UFS path.
getSurplusQueuedTaskCount() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns an estimate of how many more locally queued tasks are held by the current worker thread than there are other worker threads that might steal them, or zero if this thread is not operating in a ForkJoinPool.
getSyncDatabaseMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 syncIntervalMs = 1;
getSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional int64 syncIntervalMs = 1;
getSyncIntervalMs() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional int64 syncIntervalMs = 1;
getSyncMetricName(long) - Static method in class alluxio.metrics.MetricKey
 
getSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool syncParentNextTime = 5;
getSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions
optional bool syncParentNextTime = 5;
getSyncParentNextTime() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool syncParentNextTime = 5;
getSyncPathCache() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional string syncpoint_path = 1;
getSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
optional string syncpoint_path = 1;
getSyncpointPath() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
optional string syncpoint_path = 1;
getSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional string syncpoint_path = 1;
getSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
optional string syncpoint_path = 1;
getSyncpointPath() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
optional string syncpoint_path = 1;
getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional string syncpoint_path = 1;
getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
optional string syncpoint_path = 1;
getSyncpointPathBytes() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
optional string syncpoint_path = 1;
getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional string syncpoint_path = 1;
getSyncpointPathBytes() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
optional string syncpoint_path = 1;
getSyncpointPathBytes() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
optional string syncpoint_path = 1;
getSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
getSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
getSyncStatus() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
getSyncStatusBuilder() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
getSyncStatusOrBuilder() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
getSyncStatusOrBuilder() - Method in class alluxio.grpc.table.AttachDatabasePResponse
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
getSyncStatusOrBuilder() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
getSyncTimesForPath(AlluxioURI) - Method in class alluxio.master.file.meta.UfsSyncPathCache
Get sync times for a given path if they exist in the cache.
getSystemGid() - Static method in class alluxio.fuse.AlluxioFuseUtils
 
getSystemStatus() - Method in class alluxio.wire.MasterWebUIOverview
Gets system status.
getSystemUid() - Static method in class alluxio.fuse.AlluxioFuseUtils
 
getTable() - Method in class alluxio.client.hive.HiveCacheContext
 
getTable(String, String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getTable(String, String) - Method in interface alluxio.client.table.TableMasterClient
Get table metadata.
getTable(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
getTable(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse
repeated string table = 1;
getTable(int) - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
repeated string table = 1;
getTable(GetTablePRequest, StreamObserver<GetTablePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Returns a specific table info
getTable(GetTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Returns a specific table info
getTable(GetTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Returns a specific table info
getTable(GetTablePRequest, StreamObserver<GetTablePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Returns a specific table info
getTableBytes(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
getTableBytes(int) - Method in class alluxio.grpc.table.GetAllTablesPResponse
repeated string table = 1;
getTableBytes(int) - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
repeated string table = 1;
getTableColumnStatistics(String, String, List<String>) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getTableColumnStatistics(String, String, List<String>) - Method in interface alluxio.client.table.TableMasterClient
Get table column statistics with given database name, table name and list of column names.
getTableColumnStatistics(GetTableColumnStatisticsPRequest, StreamObserver<GetTableColumnStatisticsPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
 
getTableColumnStatistics(GetTableColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
 
getTableColumnStatistics(GetTableColumnStatisticsPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
 
getTableColumnStatistics(GetTableColumnStatisticsPRequest, StreamObserver<GetTableColumnStatisticsPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
GetTableColumnStatisticsPRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPRequest
GetTableColumnStatisticsPRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPRequest
GetTableColumnStatisticsPRequestOrBuilder - Interface in alluxio.grpc.table
 
GetTableColumnStatisticsPResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPResponse
GetTableColumnStatisticsPResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTableColumnStatisticsPResponse
GetTableColumnStatisticsPResponseOrBuilder - Interface in alluxio.grpc.table
 
getTableCount() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
getTableCount() - Method in class alluxio.grpc.table.GetAllTablesPResponse
repeated string table = 1;
getTableCount() - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
repeated string table = 1;
getTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
getTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse
optional .alluxio.grpc.table.TableInfo table_info = 1;
getTableInfo() - Method in interface alluxio.grpc.table.GetTablePResponseOrBuilder
optional .alluxio.grpc.table.TableInfo table_info = 1;
getTableInfoBuilder() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
getTableInfoOrBuilder() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
getTableInfoOrBuilder() - Method in class alluxio.grpc.table.GetTablePResponse
optional .alluxio.grpc.table.TableInfo table_info = 1;
getTableInfoOrBuilder() - Method in interface alluxio.grpc.table.GetTablePResponseOrBuilder
optional .alluxio.grpc.table.TableInfo table_info = 1;
getTableList() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
getTableList() - Method in class alluxio.grpc.table.GetAllTablesPResponse
repeated string table = 1;
getTableList() - Method in interface alluxio.grpc.table.GetAllTablesPResponseOrBuilder
repeated string table = 1;
getTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
optional string table_name = 2;
getTableName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
optional string table_name = 2;
getTableName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.GetTablePRequest
optional string table_name = 2;
getTableName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string table_name = 4;
getTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional string table_name = 4;
getTableName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional string table_name = 4;
getTableName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.ReadTablePRequest
optional string table_name = 2;
getTableName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.TableInfo
optional string table_name = 2;
getTableName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.TransformJobInfo
optional string table_name = 2;
getTableName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string table_name = 2;
getTableName() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string table_name = 2;
getTableName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.GetTablePRequest
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string table_name = 4;
getTableNameBytes() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional string table_name = 4;
getTableNameBytes() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional string table_name = 4;
getTableNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.ReadTablePRequest
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.TableInfo
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.TransformJobInfo
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string table_name = 2;
getTableNameBytes() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string table_name = 2;
getTableNameBytes() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string table_name = 2;
GetTablePRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTablePRequest
GetTablePRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTablePRequest
GetTablePRequestOrBuilder - Interface in alluxio.grpc.table
 
GetTablePResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTablePResponse
GetTablePResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTablePResponse
GetTablePResponseOrBuilder - Interface in alluxio.grpc.table
 
getTablesErrors() - Method in class alluxio.grpc.table.SyncStatus.Builder
Deprecated.
getTablesErrors() - Method in class alluxio.grpc.table.SyncStatus
Deprecated.
getTablesErrors() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
Deprecated.
getTablesErrorsCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
getTablesErrorsCount() - Method in class alluxio.grpc.table.SyncStatus
 
getTablesErrorsCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
map<string, string> tables_errors = 1;
getTablesErrorsMap() - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
getTablesErrorsMap() - Method in class alluxio.grpc.table.SyncStatus
map<string, string> tables_errors = 1;
getTablesErrorsMap() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
map<string, string> tables_errors = 1;
getTablesErrorsOrDefault(String, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
getTablesErrorsOrDefault(String, String) - Method in class alluxio.grpc.table.SyncStatus
map<string, string> tables_errors = 1;
getTablesErrorsOrDefault(String, String) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
map<string, string> tables_errors = 1;
getTablesErrorsOrThrow(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
getTablesErrorsOrThrow(String) - Method in class alluxio.grpc.table.SyncStatus
map<string, string> tables_errors = 1;
getTablesErrorsOrThrow(String) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
map<string, string> tables_errors = 1;
getTablesIgnored(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
getTablesIgnored(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_ignored = 2;
getTablesIgnored(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_ignored = 2;
getTablesIgnoredBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
getTablesIgnoredBytes(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_ignored = 2;
getTablesIgnoredBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_ignored = 2;
getTablesIgnoredCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
getTablesIgnoredCount() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_ignored = 2;
getTablesIgnoredCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_ignored = 2;
getTablesIgnoredList() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
getTablesIgnoredList() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_ignored = 2;
getTablesIgnoredList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_ignored = 2;
getTablesRemoved(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
getTablesRemoved(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_removed = 5;
getTablesRemoved(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_removed = 5;
getTablesRemovedBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
getTablesRemovedBytes(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_removed = 5;
getTablesRemovedBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_removed = 5;
getTablesRemovedCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
getTablesRemovedCount() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_removed = 5;
getTablesRemovedCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_removed = 5;
getTablesRemovedList() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
getTablesRemovedList() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_removed = 5;
getTablesRemovedList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_removed = 5;
getTablesUnchanged(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
getTablesUnchanged(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_unchanged = 3;
getTablesUnchanged(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_unchanged = 3;
getTablesUnchangedBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
getTablesUnchangedBytes(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_unchanged = 3;
getTablesUnchangedBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_unchanged = 3;
getTablesUnchangedCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
getTablesUnchangedCount() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_unchanged = 3;
getTablesUnchangedCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_unchanged = 3;
getTablesUnchangedList() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
getTablesUnchangedList() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_unchanged = 3;
getTablesUnchangedList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_unchanged = 3;
getTablesUpdated(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
getTablesUpdated(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_updated = 4;
getTablesUpdated(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_updated = 4;
getTablesUpdatedBytes(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
getTablesUpdatedBytes(int) - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_updated = 4;
getTablesUpdatedBytes(int) - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_updated = 4;
getTablesUpdatedCount() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
getTablesUpdatedCount() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_updated = 4;
getTablesUpdatedCount() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_updated = 4;
getTablesUpdatedList() - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
getTablesUpdatedList() - Method in class alluxio.grpc.table.SyncStatus
repeated string tables_updated = 4;
getTablesUpdatedList() - Method in interface alluxio.grpc.table.SyncStatusOrBuilder
repeated string tables_updated = 4;
getTag() - Method in class alluxio.grpc.UfsReadOptions.Builder
required string tag = 1;
getTag() - Method in class alluxio.grpc.UfsReadOptions
required string tag = 1;
getTag() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
required string tag = 1;
getTag(Fingerprint.Tag) - Method in class alluxio.underfs.Fingerprint
 
getTagBytes() - Method in class alluxio.grpc.UfsReadOptions.Builder
required string tag = 1;
getTagBytes() - Method in class alluxio.grpc.UfsReadOptions
required string tag = 1;
getTagBytes() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
required string tag = 1;
getTagMap() - Method in class alluxio.s3.TaggingData
Returns the Map object containing the contents of the TagSet.
getTags() - Method in class alluxio.grpc.Metric.Builder
Deprecated.
getTags() - Method in class alluxio.grpc.Metric
Deprecated.
getTags() - Method in interface alluxio.grpc.MetricOrBuilder
Deprecated.
getTags() - Method in class alluxio.metrics.Metric
 
getTagsCount() - Method in class alluxio.grpc.Metric.Builder
 
getTagsCount() - Method in class alluxio.grpc.Metric
 
getTagsCount() - Method in interface alluxio.grpc.MetricOrBuilder
map<string, string> tags = 6;
getTagsMap() - Method in class alluxio.grpc.Metric.Builder
map<string, string> tags = 6;
getTagsMap() - Method in class alluxio.grpc.Metric
map<string, string> tags = 6;
getTagsMap() - Method in interface alluxio.grpc.MetricOrBuilder
map<string, string> tags = 6;
getTagsOrDefault(String, String) - Method in class alluxio.grpc.Metric.Builder
map<string, string> tags = 6;
getTagsOrDefault(String, String) - Method in class alluxio.grpc.Metric
map<string, string> tags = 6;
getTagsOrDefault(String, String) - Method in interface alluxio.grpc.MetricOrBuilder
map<string, string> tags = 6;
getTagsOrThrow(String) - Method in class alluxio.grpc.Metric.Builder
map<string, string> tags = 6;
getTagsOrThrow(String) - Method in class alluxio.grpc.Metric
map<string, string> tags = 6;
getTagsOrThrow(String) - Method in interface alluxio.grpc.MetricOrBuilder
map<string, string> tags = 6;
getTagsPerBucket() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
getTagUfsValueFromFullName(String) - Static method in class alluxio.metrics.Metric
Gets value of ufs tag from the full metric name.
getTargetBuffer() - Method in class alluxio.file.NettyBufTargetBuffer
Get the internal Bytebuf object.
getTargetDirectory() - Method in class alluxio.grpc.BackupPRequest.Builder
optional string targetDirectory = 2;
getTargetDirectory() - Method in class alluxio.grpc.BackupPRequest
optional string targetDirectory = 2;
getTargetDirectory() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
optional string targetDirectory = 2;
getTargetDirectoryBytes() - Method in class alluxio.grpc.BackupPRequest.Builder
optional string targetDirectory = 2;
getTargetDirectoryBytes() - Method in class alluxio.grpc.BackupPRequest
optional string targetDirectory = 2;
getTargetDirectoryBytes() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
optional string targetDirectory = 2;
getTaskArgs() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes taskArgs = 4;
getTaskArgs() - Method in class alluxio.grpc.RunTaskCommand
optional bytes taskArgs = 4;
getTaskArgs() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional bytes taskArgs = 4;
getTaskExecutorPoolSize() - Method in class alluxio.worker.job.task.TaskExecutorManager
 
getTaskId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 taskId = 2;
getTaskId() - Method in class alluxio.grpc.CancelTaskCommand
optional int64 taskId = 2;
getTaskId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
optional int64 taskId = 2;
getTaskId() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 taskId = 2;
getTaskId() - Method in class alluxio.grpc.RunTaskCommand
optional int64 taskId = 2;
getTaskId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional int64 taskId = 2;
getTaskId() - Method in class alluxio.job.RunTaskContext
 
getTaskId() - Method in class alluxio.job.wire.TaskInfo
 
getTaskId() - Method in class alluxio.scheduler.job.Task
Get task id.
getTaskIdList() - Method in class alluxio.job.plan.meta.PlanInfo
 
getTaskInfo(long) - Method in class alluxio.job.plan.meta.PlanInfo
 
getTaskInfoList() - Method in class alluxio.job.plan.meta.PlanInfo
 
getTaskInfos(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfos(int) - Method in class alluxio.grpc.JobHeartbeatPRequest
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfos(int) - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosBuilderList() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosCount() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosCount() - Method in class alluxio.grpc.JobHeartbeatPRequest
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosCount() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosList() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosList() - Method in class alluxio.grpc.JobHeartbeatPRequest
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosList() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosOrBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosOrBuilder(int) - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosOrBuilderList() - Method in class alluxio.grpc.JobHeartbeatPRequest
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskInfosOrBuilderList() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
getTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 taskPoolSize = 5;
getTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth
optional int32 taskPoolSize = 5;
getTaskPoolSize() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int32 taskPoolSize = 5;
getTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
optional int32 taskPoolSize = 1;
getTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
optional int32 taskPoolSize = 1;
getTaskPoolSize() - Method in interface alluxio.grpc.SetTaskPoolSizeCommandOrBuilder
optional int32 taskPoolSize = 1;
getTaskPoolSize() - Method in class alluxio.job.wire.JobWorkerHealth
 
getTasks() - Method in class alluxio.cli.HdfsValidationTool
 
getTasks() - Method in class alluxio.cli.HmsValidationTool
 
getTasks() - Method in class alluxio.cli.ValidateEnv
Get the tasks registered.
getTasks() - Method in interface alluxio.cli.ValidationTool
 
getTaskStat() - Method in class alluxio.scheduler.job.Task
 
getTempBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Gets the temp metadata of a specific block from local storage.
getTempBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Gets the TempBlockMeta from this storage dir by its block id.
getTemporaryCheckpoints() - Method in class alluxio.master.journal.ufs.UfsJournalSnapshot
 
getTemporaryToken(String, String, String, Mode.Bits) - Method in interface alluxio.underfs.UnderFileSystem
Gets a temporary token according to path, sid, effect and action.
getTempUfsPath() - Method in class alluxio.master.file.meta.InodeFile
 
getTempUfsPath() - Method in interface alluxio.master.file.meta.InodeFileView
 
getTempUfsPath() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getTempUfsPath() - Method in class alluxio.master.file.PersistJob
 
getTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string temp_ufs_path = 23;
getTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string temp_ufs_path = 23;
getTempUfsPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string temp_ufs_path = 23;
getTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string tempUfsPath = 12;
getTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string tempUfsPath = 12;
getTempUfsPath() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string tempUfsPath = 12;
getTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string temp_ufs_path = 11;
getTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional string temp_ufs_path = 11;
getTempUfsPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional string temp_ufs_path = 11;
getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string temp_ufs_path = 23;
getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string temp_ufs_path = 23;
getTempUfsPathBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string temp_ufs_path = 23;
getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string tempUfsPath = 12;
getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string tempUfsPath = 12;
getTempUfsPathBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string tempUfsPath = 12;
getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string temp_ufs_path = 11;
getTempUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional string temp_ufs_path = 11;
getTempUfsPathBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional string temp_ufs_path = 11;
getThis() - Method in class alluxio.master.file.contexts.CreatePathContext
Note: This is safe as 'K' extends CreatePathContext.
getThis() - Method in class alluxio.master.file.meta.MutableInode
 
getThis() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
getThis() - Method in class alluxio.master.file.meta.MutableInodeFile
 
getThread(ExecutorService) - Static method in class alluxio.master.transport.GrpcMessagingContext
Gets the thread from a single threaded executor service.
getThreadCountIoMbps() - Method in class alluxio.stress.client.ClientIOSummary
 
getThreadCountResults() - Method in class alluxio.stress.client.ClientIOTaskResult
 
getThreadIdentifier(Thread) - Static method in class alluxio.util.ThreadUtils
 
getThreadName() - Method in class alluxio.heartbeat.ScheduledTimer
 
getThreadNames() - Static method in class alluxio.heartbeat.HeartbeatScheduler
 
getThreads(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
getThreads(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
repeated string threads = 1;
getThreads(int) - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
repeated string threads = 1;
getThreadsBytes(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
getThreadsBytes(int) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
repeated string threads = 1;
getThreadsBytes(int) - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
repeated string threads = 1;
getThreadsCount() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
getThreadsCount() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
repeated string threads = 1;
getThreadsCount() - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
repeated string threads = 1;
getThreadsList() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
getThreadsList() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
repeated string threads = 1;
getThreadsList() - Method in interface alluxio.grpc.GetStateLockHoldersPResponseOrBuilder
repeated string threads = 1;
getThroughput() - Method in class alluxio.stress.common.GeneralBenchSummary
 
getThroughput() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
getThroughputPercentiles() - Method in class alluxio.stress.worker.WorkerBenchSummary
 
getThroughputPercentiles() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
getTid() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
getTier() - Method in class alluxio.grpc.WriteRequestCommand.Builder
This is only applicable for block write.
getTier() - Method in class alluxio.grpc.WriteRequestCommand
This is only applicable for block write.
getTier() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
This is only applicable for block write.
getTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
getTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int32 tier = 3;
getTier() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int32 tier = 3;
getTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for block write.
getTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
This is only applicable for block write.
getTier() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
This is only applicable for block write.
getTier() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string tier = 2;
getTier() - Method in class alluxio.proto.meta.Block.BlockLocation
optional string tier = 2;
getTier() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional string tier = 2;
getTier() - Method in class alluxio.worker.netty.BlockWriteRequest
 
getTierAlias() - Method in class alluxio.grpc.BlockLocation.Builder
optional string tierAlias = 3;
getTierAlias() - Method in class alluxio.grpc.BlockLocation
optional string tierAlias = 3;
getTierAlias() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional string tierAlias = 3;
getTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string tierAlias = 1;
getTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto
optional string tierAlias = 1;
getTierAlias() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
optional string tierAlias = 1;
getTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the alias of the target tier
getTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest
the alias of the target tier
getTierAlias() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the alias of the target tier
getTierAlias() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
getTierAlias() - Method in class alluxio.util.webui.UIStorageDir
Gets tier alias.
getTierAlias() - Method in class alluxio.util.webui.UIUsageOnTier
Gets tier alias.
getTierAlias() - Method in class alluxio.wire.BlockLocation
 
getTierAlias() - Method in interface alluxio.worker.block.meta.StorageTier
 
getTierAliasBytes() - Method in class alluxio.grpc.BlockLocation.Builder
optional string tierAlias = 3;
getTierAliasBytes() - Method in class alluxio.grpc.BlockLocation
optional string tierAlias = 3;
getTierAliasBytes() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional string tierAlias = 3;
getTierAliasBytes() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string tierAlias = 1;
getTierAliasBytes() - Method in class alluxio.grpc.BlockStoreLocationProto
optional string tierAlias = 1;
getTierAliasBytes() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
optional string tierAlias = 1;
getTierAliasBytes() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the alias of the target tier
getTierAliasBytes() - Method in class alluxio.grpc.CommitBlockPRequest
the alias of the target tier
getTierAliasBytes() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the alias of the target tier
getTierBytes() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string tier = 2;
getTierBytes() - Method in class alluxio.proto.meta.Block.BlockLocation
optional string tier = 2;
getTierBytes() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional string tier = 2;
getTierCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getTierCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getTierOrdinal() - Method in interface alluxio.worker.block.meta.StorageTier
 
getTierPaths() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getTiers(int) - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
getTiers(int) - Method in class alluxio.grpc.TierList
repeated int64 tiers = 1;
getTiers(int) - Method in interface alluxio.grpc.TierListOrBuilder
repeated int64 tiers = 1;
getTiersCount() - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
getTiersCount() - Method in class alluxio.grpc.TierList
repeated int64 tiers = 1;
getTiersCount() - Method in interface alluxio.grpc.TierListOrBuilder
repeated int64 tiers = 1;
getTiersList() - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
getTiersList() - Method in class alluxio.grpc.TierList
repeated int64 tiers = 1;
getTiersList() - Method in interface alluxio.grpc.TierListOrBuilder
repeated int64 tiers = 1;
getTimedOutSessions() - Method in class alluxio.Sessions
Gets the sessions that timed out.
getTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string timeExpression = 4;
getTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions
optional string timeExpression = 4;
getTimeExpression() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string timeExpression = 4;
getTimeExpressionBytes() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string timeExpression = 4;
getTimeExpressionBytes() - Method in class alluxio.grpc.AddPolicyPOptions
optional string timeExpression = 4;
getTimeExpressionBytes() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string timeExpression = 4;
getTimeNs() - Method in class alluxio.stress.cli.Benchmark.MethodStatistics
 
getTimeoutDuration() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getTimeoutMs() - Method in class alluxio.network.netty.NettyRPCContext
 
getTimeoutMs() - Method in class alluxio.util.WaitForOptions
 
getTimeoutThreads() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getTimer() - Method in class alluxio.master.file.PersistJob
 
getTimerClass(String) - Static method in class alluxio.heartbeat.HeartbeatContext
 
getTimerClasses() - Static method in class alluxio.heartbeat.HeartbeatContext
 
getTimeSeries() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getTimeSeries() - Method in interface alluxio.master.file.FileSystemMaster
 
getTimeSeries() - Method in class alluxio.master.metrics.TimeSeriesStore
 
getTimeSeriesMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
 
getTimeStamp() - Method in class alluxio.metrics.TimeSeries.DataPoint
 
getTimestampGetter() - Method in class alluxio.master.predicate.DatePredicate.Factory
 
getTimestampGetter() - Method in class alluxio.master.predicate.DatePredicate.LastModifiedDateFactory
 
getTimestampGetter() - Method in class alluxio.master.predicate.TimePredicate.Factory
 
getTimestampGetter() - Method in class alluxio.master.predicate.TimePredicate.UnmodifiedForFactory
 
getTimeToFirstBytePerThread() - Method in class alluxio.stress.client.ClientIOTaskResult
 
getTitle() - Method in class alluxio.stress.graph.Graph
 
getTmpDir() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
getTmpDir(List<String>) - Static method in class alluxio.util.CommonUtils
 
getToBePersistedIds() - Method in class alluxio.master.file.meta.InodeTree
 
getToBePersistedIds() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getToDelete() - Method in class alluxio.s3.DeleteObjectsRequest
 
getToRemoveBlockCount() - Method in class alluxio.master.block.meta.MasterWorkerInfo
Returns the number of blocks that should be removed from the worker.
getToRemoveBlocks() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getTotal() - Method in class alluxio.wire.Capacity
 
getTotalAllocatedBytes() - Method in class alluxio.wire.JournalDiskInfo
 
getTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getTotalBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest
Deprecated.
getTotalBytesOnTiers() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
Deprecated.
getTotalBytesOnTiers() - Method in interface alluxio.master.block.BlockMaster
 
getTotalBytesOnTiers() - Method in class alluxio.master.block.DefaultBlockMaster
 
getTotalBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getTotalBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
getTotalBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getTotalBytesOnTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of total bytes on each tier
getTotalBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
getTotalBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of total bytes on each tier
getTotalBytesOnTiersMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of total bytes on each tier
getTotalBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
getTotalBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of total bytes on each tier
getTotalBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of total bytes on each tier
getTotalBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
getTotalBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of total bytes on each tier
getTotalBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of total bytes on each tier
getTotalBytesReadDomainSocket() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read from domain socket.
getTotalBytesReadDomainSocketThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read from domain socket throughput.
getTotalBytesReadRemote() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read remote.
getTotalBytesReadRemoteThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read remote throughput.
getTotalBytesReadUfs() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read ufs.
getTotalBytesReadUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read ufs throughput.
getTotalBytesWrittenDomainSocket() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written through domain socket.
getTotalBytesWrittenDomainSocketThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written through domain socket throughput.
getTotalBytesWrittenRemote() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written remote.
getTotalBytesWrittenRemoteThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written remote throughput.
getTotalBytesWrittenUfs() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written ufs.
getTotalBytesWrittenUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written ufs throughput.
getTotalCapacityOnTiers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get capacity by tiers.
getTotalExtraTime() - Method in class alluxio.util.JvmPauseMonitor
 
getTotalListings() - Method in class alluxio.master.file.contexts.ListStatusContext
Get the value set by setTotalListing.
getTotalPath() - Method in class alluxio.wire.MasterWebUIOverview
Gets total path.
getTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
required string transferId = 1;
getTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
required string transferId = 1;
getTransferId() - Method in interface alluxio.grpc.GetTransferLeaderMessagePRequestOrBuilder
required string transferId = 1;
getTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
required string transferId = 1;
getTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse
required string transferId = 1;
getTransferId() - Method in interface alluxio.grpc.TransferLeadershipPResponseOrBuilder
required string transferId = 1;
getTransferIdBytes() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
required string transferId = 1;
getTransferIdBytes() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
required string transferId = 1;
getTransferIdBytes() - Method in interface alluxio.grpc.GetTransferLeaderMessagePRequestOrBuilder
required string transferId = 1;
getTransferIdBytes() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
required string transferId = 1;
getTransferIdBytes() - Method in class alluxio.grpc.TransferLeadershipPResponse
required string transferId = 1;
getTransferIdBytes() - Method in interface alluxio.grpc.TransferLeadershipPResponseOrBuilder
required string transferId = 1;
getTransferLeaderMessage(String) - Method in interface alluxio.client.journal.JournalMasterClient
Gets exception messages thrown when transferring the leader.
getTransferLeaderMessage(String) - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
getTransferLeaderMessage(GetTransferLeaderMessagePRequest, StreamObserver<GetTransferLeaderMessagePResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
Gets exception message throwing when transfer leader.
getTransferLeaderMessage(GetTransferLeaderMessagePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
Gets exception message throwing when transfer leader.
getTransferLeaderMessage(GetTransferLeaderMessagePRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
Gets exception message throwing when transfer leader.
getTransferLeaderMessage(GetTransferLeaderMessagePRequest, StreamObserver<GetTransferLeaderMessagePResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
Gets exception message throwing when transfer leader.
getTransferLeaderMessage(GetTransferLeaderMessagePRequest, StreamObserver<GetTransferLeaderMessagePResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
 
GetTransferLeaderMessageOptions - Class in alluxio.grpc
GetTransferLeaderMessage API
GetTransferLeaderMessageOptions.Builder - Class in alluxio.grpc
GetTransferLeaderMessage API
GetTransferLeaderMessageOptionsOrBuilder - Interface in alluxio.grpc
 
GetTransferLeaderMessagePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePRequest
GetTransferLeaderMessagePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePRequest
GetTransferLeaderMessagePRequestOrBuilder - Interface in alluxio.grpc
 
GetTransferLeaderMessagePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePResponse
GetTransferLeaderMessagePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.GetTransferLeaderMessagePResponse
GetTransferLeaderMessagePResponseOrBuilder - Interface in alluxio.grpc
 
getTransferLeadershipMethod() - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
getTransferManager() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
getTransferManager() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getTransformations(int) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
getTransformations(int) - Method in class alluxio.grpc.table.Partition
The latest transformation is in the back of the list.
getTransformations(int) - Method in interface alluxio.grpc.table.PartitionOrBuilder
The latest transformation is in the back of the list.
getTransformationsBuilder(int) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
getTransformationsBuilderList() - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
getTransformationsCount() - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
getTransformationsCount() - Method in class alluxio.grpc.table.Partition
The latest transformation is in the back of the list.
getTransformationsCount() - Method in interface alluxio.grpc.table.PartitionOrBuilder
The latest transformation is in the back of the list.
getTransformationsList() - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
getTransformationsList() - Method in class alluxio.grpc.table.Partition
The latest transformation is in the back of the list.
getTransformationsList() - Method in interface alluxio.grpc.table.PartitionOrBuilder
The latest transformation is in the back of the list.
getTransformationsOrBuilder(int) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
getTransformationsOrBuilder(int) - Method in class alluxio.grpc.table.Partition
The latest transformation is in the back of the list.
getTransformationsOrBuilder(int) - Method in interface alluxio.grpc.table.PartitionOrBuilder
The latest transformation is in the back of the list.
getTransformationsOrBuilderList() - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
getTransformationsOrBuilderList() - Method in class alluxio.grpc.table.Partition
The latest transformation is in the back of the list.
getTransformationsOrBuilderList() - Method in interface alluxio.grpc.table.PartitionOrBuilder
The latest transformation is in the back of the list.
getTransformJobInfo(long) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
getTransformJobInfo(long) - Method in interface alluxio.client.table.TableMasterClient
 
getTransformJobInfo(GetTransformJobInfoPRequest, StreamObserver<GetTransformJobInfoPResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Gets information of transformation jobs.
getTransformJobInfo(GetTransformJobInfoPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Gets information of transformation jobs.
getTransformJobInfo(GetTransformJobInfoPRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Gets information of transformation jobs.
getTransformJobInfo(GetTransformJobInfoPRequest, StreamObserver<GetTransformJobInfoPResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Gets information of transformation jobs.
GetTransformJobInfoPRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTransformJobInfoPRequest
GetTransformJobInfoPRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTransformJobInfoPRequest
GetTransformJobInfoPRequestOrBuilder - Interface in alluxio.grpc.table
 
GetTransformJobInfoPResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTransformJobInfoPResponse
GetTransformJobInfoPResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.GetTransformJobInfoPResponse
GetTransformJobInfoPResponseOrBuilder - Interface in alluxio.grpc.table
 
getTransformTableMethod() - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
getTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
getTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
getTransMsg() - Method in interface alluxio.grpc.GetTransferLeaderMessagePResponseOrBuilder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
getTransMsgBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
getTransMsgOrBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
getTransMsgOrBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
getTransMsgOrBuilder() - Method in interface alluxio.grpc.GetTransferLeaderMessagePResponseOrBuilder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
getTriggerEventsWithParam() - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Get the TriggerEventsWithParam.
getTriggerPolicyMethod() - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
getTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
the timestamp in nanoseconds when this FileStatus is refreshed
getTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
the timestamp in nanoseconds when this FileStatus is refreshed
getTs() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
the timestamp in nanoseconds when this FileStatus is refreshed
getTtl() - Method in class alluxio.client.file.URIStatus
 
getTtl() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 ttl = 15;
getTtl() - Method in class alluxio.grpc.FileInfo
optional int64 ttl = 15;
getTtl() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 ttl = 15;
getTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 ttl = 2;
getTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional int64 ttl = 2;
getTtl() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional int64 ttl = 2;
getTtl() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getTtl() - Method in class alluxio.master.file.meta.Inode
 
getTtl() - Method in interface alluxio.master.file.meta.InodeView
 
getTtl() - Method in class alluxio.master.file.meta.MutableInode
 
getTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 ttl = 13;
getTtl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 ttl = 13;
getTtl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 ttl = 13;
getTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
getTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 ttl = 4;
getTtl() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 ttl = 4;
getTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 ttl = 12;
getTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 ttl = 12;
getTtl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 ttl = 12;
getTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 ttl = 4;
getTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 ttl = 4;
getTtl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 ttl = 4;
getTtl() - Method in class alluxio.wire.FileInfo
 
getTtlAction() - Method in class alluxio.client.file.URIStatus
 
getTtlAction() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.TtlAction ttlAction = 22;
getTtlAction() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.TtlAction ttlAction = 22;
getTtlAction() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.TtlAction ttlAction = 22;
getTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.TtlAction ttlAction = 3;
getTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional .alluxio.grpc.TtlAction ttlAction = 3;
getTtlAction() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional .alluxio.grpc.TtlAction ttlAction = 3;
getTtlAction() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getTtlAction() - Method in class alluxio.master.file.meta.Inode
 
getTtlAction() - Method in interface alluxio.master.file.meta.InodeView
 
getTtlAction() - Method in class alluxio.master.file.meta.MutableInode
 
getTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
getTtlAction() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
getTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.grpc.TtlAction ttl_action = 5;
getTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.grpc.TtlAction ttl_action = 5;
getTtlAction() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.grpc.TtlAction ttl_action = 5;
getTtlAction() - Method in class alluxio.wire.FileInfo
 
getTtlBuckets() - Method in class alluxio.master.file.meta.InodeTree
 
getTtlBuckets() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
getTtlCheckIntervalSeconds() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
getTtlIntervalEndTimeMs() - Method in class alluxio.master.file.meta.TtlBucket
 
getTtlIntervalMs() - Static method in class alluxio.master.file.meta.TtlBucket
 
getTtlIntervalStartTimeMs() - Method in class alluxio.master.file.meta.TtlBucket
 
getTtlThresholdSeconds() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
getTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 tx_id = 2;
getTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
optional int64 tx_id = 2;
getTxId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
optional int64 tx_id = 2;
getType() - Method in class alluxio.cli.HdfsValidationToolFactory
 
getType() - Method in class alluxio.cli.HmsValidationToolFactory
 
getType() - Method in interface alluxio.cli.ValidationToolFactory
 
getType() - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
getType() - Method in enum alluxio.client.file.dora.netty.PartialReadException.CauseType
 
getType() - Method in class alluxio.conf.PropertyKey
 
getType() - Method in class alluxio.conf.Source
 
getType() - Method in class alluxio.grpc.JobDescription.Builder
required string type = 1;
getType() - Method in class alluxio.grpc.JobDescription
required string type = 1;
getType() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
required string type = 1;
getType() - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.JobType type = 8;
getType() - Method in class alluxio.grpc.JobInfo
optional .alluxio.grpc.job.JobType type = 8;
getType() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional .alluxio.grpc.job.JobType type = 8;
getType() - Method in class alluxio.grpc.PAclEntry.Builder
optional .alluxio.grpc.file.PAclEntryType type = 1;
getType() - Method in class alluxio.grpc.PAclEntry
optional .alluxio.grpc.file.PAclEntryType type = 1;
getType() - Method in interface alluxio.grpc.PAclEntryOrBuilder
optional .alluxio.grpc.file.PAclEntryType type = 1;
getType() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string type = 3;
getType() - Method in class alluxio.grpc.table.FieldSchema
optional string type = 3;
getType() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string type = 3;
getType() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
getType() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
getType() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
getType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.grpc.block.RequestType type = 1;
getType() - Method in class alluxio.grpc.WriteRequestCommand
optional .alluxio.grpc.block.RequestType type = 1;
getType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional .alluxio.grpc.block.RequestType type = 1;
getType() - Method in class alluxio.job.CopyJobRequest
 
getType() - Method in class alluxio.job.JobDescription
 
getType() - Method in interface alluxio.job.JobRequest
 
getType() - Method in class alluxio.job.LoadJobRequest
 
getType() - Method in class alluxio.job.MoveJobRequest
 
getType() - Method in interface alluxio.master.file.contexts.CallTracker
 
getType() - Method in class alluxio.master.file.contexts.GrpcCallTracker
 
getType() - Method in class alluxio.master.journal.checkpoint.CheckpointInputStream
 
getType() - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
 
getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
 
getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
 
getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
 
getType() - Method in class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
 
getType() - Method in class alluxio.network.protocol.RPCMessage
Returns the type of the message.
getType() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
getType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
getType() - Method in interface alluxio.proto.dataserver.Protocol.ReadResponseOrBuilder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
getType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
getType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional .alluxio.proto.dataserver.RequestType type = 1;
getType() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional .alluxio.proto.dataserver.RequestType type = 1;
getType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional .alluxio.proto.shared.AclEntryType type = 1;
getType() - Method in class alluxio.proto.shared.Acl.AclEntry
optional .alluxio.proto.shared.AclEntryType type = 1;
getType() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
optional .alluxio.proto.shared.AclEntryType type = 1;
getType() - Method in class alluxio.security.authorization.AclEntry
 
getType() - Method in class alluxio.stress.cli.Benchmark.ProfileInput
 
getType() - Method in class alluxio.worker.http.ResponseFileInfo
Get the file type.
getTypeBytes() - Method in class alluxio.grpc.JobDescription.Builder
required string type = 1;
getTypeBytes() - Method in class alluxio.grpc.JobDescription
required string type = 1;
getTypeBytes() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
required string type = 1;
getTypeBytes() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string type = 3;
getTypeBytes() - Method in class alluxio.grpc.table.FieldSchema
optional string type = 3;
getTypeBytes() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string type = 3;
getUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
getUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_connection_uri = 2;
getUdbConnectionUri() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_connection_uri = 2;
getUdbConnectionUriBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
getUdbConnectionUriBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_connection_uri = 2;
getUdbConnectionUriBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_connection_uri = 2;
getUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
getUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_db_name = 3;
getUdbDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_db_name = 3;
getUdbDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
getUdbDbNameBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_db_name = 3;
getUdbDbNameBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_db_name = 3;
getUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
getUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_type = 1;
getUdbType() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_type = 1;
getUdbTypeBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
getUdbTypeBytes() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_type = 1;
getUdbTypeBytes() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_type = 1;
getUfsAddress() - Method in class alluxio.client.file.options.UfsFileSystemOptions
 
getUfsAddress() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getUfsAddress() - Method in interface alluxio.master.file.FileSystemMaster
 
getUfsBaseFileSystem() - Method in class alluxio.client.file.DelegatingFileSystem
 
getUfsBaseFileSystem() - Method in interface alluxio.client.file.FileSystem
 
getUfsBaseFileSystem() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
getUfsBlockPath(UfsManager.UfsClient, long) - Static method in class alluxio.worker.BlockUtils
For a given block ID, derives the corresponding UFS file of this block if it falls back to be stored in UFS.
getUfsCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsCapacityBytes = 3 [default = -1];
getUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo
optional int64 ufsCapacityBytes = 3 [default = -1];
getUfsCapacityBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional int64 ufsCapacityBytes = 3 [default = -1];
getUfsCapacityBytes() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs capacity bytes.
getUfsCapacityBytes() - Method in class alluxio.wire.MountPointInfo
 
getUfsClient(long) - Method in class alluxio.master.file.meta.MountTable
Get the associated ufs client with the mount id.
getUfsClient() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getUfsContentHash() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
 
getUfsContentHash() - Method in interface alluxio.client.block.stream.DataWriter
 
getUfsContentHash() - Method in class alluxio.client.block.stream.GrpcDataWriter
 
getUfsContentHash() - Method in class alluxio.client.block.stream.NettyDataWriter
 
getUfsContentHash() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
getUfsFileStatus() - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
getUfsFileStatus() - Method in class alluxio.grpc.UfsStatus
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
getUfsFileStatus() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
getUfsFileStatusBuilder() - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
getUfsFileStatusOrBuilder() - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
getUfsFileStatusOrBuilder() - Method in class alluxio.grpc.UfsStatus
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
getUfsFileStatusOrBuilder() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
getUfsFileSystemOptions() - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
getUfsFileSystemOptions() - Method in class alluxio.client.file.options.FileSystemOptions
 
getUfsFingerprint() - Method in class alluxio.client.file.URIStatus
 
getUfsFingerprint() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsFingerprint = 26;
getUfsFingerprint() - Method in class alluxio.grpc.FileInfo
optional string ufsFingerprint = 26;
getUfsFingerprint() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsFingerprint = 26;
getUfsFingerprint() - Method in class alluxio.master.file.contexts.SetAttributeContext
 
getUfsFingerprint() - Method in class alluxio.master.file.meta.Inode
 
getUfsFingerprint() - Method in interface alluxio.master.file.meta.InodeView
 
getUfsFingerprint() - Method in class alluxio.master.file.meta.MutableInode
 
getUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional string ufs_fingerprint = 5;
getUfsFingerprint() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional string ufs_fingerprint = 5;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string ufs_fingerprint = 18;
getUfsFingerprint() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string ufs_fingerprint = 18;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string ufs_fingerprint = 10;
getUfsFingerprint() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string ufs_fingerprint = 10;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string ufs_fingerprint = 15;
getUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string ufs_fingerprint = 15;
getUfsFingerprint() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string ufs_fingerprint = 15;
getUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string ufs_fingerprint = 11;
getUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string ufs_fingerprint = 11;
getUfsFingerprint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string ufs_fingerprint = 11;
getUfsFingerprint() - Method in class alluxio.wire.FileInfo
 
getUfsFingerprintBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsFingerprint = 26;
getUfsFingerprintBytes() - Method in class alluxio.grpc.FileInfo
optional string ufsFingerprint = 26;
getUfsFingerprintBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsFingerprint = 26;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional string ufs_fingerprint = 5;
getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional string ufs_fingerprint = 5;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string ufs_fingerprint = 18;
getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string ufs_fingerprint = 18;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string ufs_fingerprint = 10;
getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string ufs_fingerprint = 10;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string ufs_fingerprint = 15;
getUfsFingerprintBytes() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string ufs_fingerprint = 15;
getUfsFingerprintBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string ufs_fingerprint = 15;
getUfsFingerprintBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string ufs_fingerprint = 11;
getUfsFingerprintBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string ufs_fingerprint = 11;
getUfsFingerprintBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string ufs_fingerprint = 11;
getUfsFullPath() - Method in class alluxio.grpc.UfsStatus.Builder
optional string ufs_full_path = 8;
getUfsFullPath() - Method in class alluxio.grpc.UfsStatus
optional string ufs_full_path = 8;
getUfsFullPath() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string ufs_full_path = 8;
getUfsFullPath() - Method in class alluxio.underfs.UfsStatus
 
getUfsFullPathBytes() - Method in class alluxio.grpc.UfsStatus.Builder
optional string ufs_full_path = 8;
getUfsFullPathBytes() - Method in class alluxio.grpc.UfsStatus
optional string ufs_full_path = 8;
getUfsFullPathBytes() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string ufs_full_path = 8;
getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterJobServiceGrpc.AsyncService
Returns the UFS information for the given mount point identified by its id.
getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceBlockingStub
Returns the UFS information for the given mount point identified by its id.
getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceFutureStub
Returns the UFS information for the given mount point identified by its id.
getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceStub
Returns the UFS information for the given mount point identified by its id.
getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in interface alluxio.grpc.FileSystemMasterWorkerServiceGrpc.AsyncService
Returns the UFS information for the given mount point identified by its id.
getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceBlockingStub
Returns the UFS information for the given mount point identified by its id.
getUfsInfo(GetUfsInfoPRequest) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceFutureStub
Returns the UFS information for the given mount point identified by its id.
getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceStub
Returns the UFS information for the given mount point identified by its id.
getUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
getUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
getUfsInfo() - Method in interface alluxio.grpc.GetUfsInfoPResponseOrBuilder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
getUfsInfo(long) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getUfsInfo(long) - Method in interface alluxio.master.file.FileSystemMaster
 
getUfsInfo(long) - Method in class alluxio.master.file.FileSystemMasterClient
 
getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterJobServiceHandler
 
getUfsInfo(GetUfsInfoPRequest, StreamObserver<GetUfsInfoPResponse>) - Method in class alluxio.master.file.FileSystemMasterWorkerServiceHandler
 
getUfsInfo(long) - Method in class alluxio.worker.file.FileSystemMasterClient
 
getUfsInfoBuilder() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
getUfsInfoOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
getUfsInfoOrBuilder() - Method in class alluxio.grpc.GetUfsInfoPResponse
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
getUfsInfoOrBuilder() - Method in interface alluxio.grpc.GetUfsInfoPResponseOrBuilder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
GetUfsInfoPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetUfsInfoPOptions
GetUfsInfoPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetUfsInfoPOptions
GetUfsInfoPOptionsOrBuilder - Interface in alluxio.grpc
 
GetUfsInfoPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetUfsInfoPRequest
GetUfsInfoPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetUfsInfoPRequest
GetUfsInfoPRequestOrBuilder - Interface in alluxio.grpc
 
GetUfsInfoPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetUfsInfoPResponse
GetUfsInfoPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.GetUfsInfoPResponse
GetUfsInfoPResponseOrBuilder - Interface in alluxio.grpc
 
getUfsInstance(String) - Method in class alluxio.worker.dora.PagedDoraWorker
 
getUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional int64 ufsLength = 1;
getUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions
optional int64 ufsLength = 1;
getUfsLength() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional int64 ufsLength = 1;
getUfsLocations(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocations(int) - Method in class alluxio.grpc.FileBlockInfo
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocations(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocations() - Method in class alluxio.wire.FileBlockInfo
 
getUfsLocationsBuilder(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsBuilderList() - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsCount() - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsCount() - Method in class alluxio.grpc.FileBlockInfo
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsCount() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsList() - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsList() - Method in class alluxio.grpc.FileBlockInfo
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsList() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsOrBuilder(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsOrBuilder(int) - Method in class alluxio.grpc.FileBlockInfo
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsOrBuilder(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsOrBuilderList() - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsOrBuilderList() - Method in class alluxio.grpc.FileBlockInfo
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsLocationsOrBuilderList() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
getUfsManager() - Method in class alluxio.job.JobServerContext
 
getUfsManager() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getUfsManager() - Method in class alluxio.master.MasterContext
 
getUfsManager() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getUfsManager() - Method in interface alluxio.worker.WorkerProcess
 
getUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
getUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
getUfsMode() - Method in interface alluxio.grpc.UpdateUfsModePOptionsOrBuilder
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
getUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
getUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
getUfsMode() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
getUfsMountPointUri() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getUfsMountPointUri() - Method in class alluxio.underfs.UfsManager.UfsClient
 
getUfsOps() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs ops.
getUfsOpsSaved() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs ops saved.
getUfsOpsSavedCounter(AlluxioURI, DefaultFileSystemMaster.Metrics.UFSOps) - Static method in class alluxio.master.file.DefaultFileSystemMaster.Metrics
Get operations saved per ufs counter.
getUfsPath() - Method in class alluxio.client.file.options.OutStreamOptions
 
getUfsPath() - Method in class alluxio.client.file.URIStatus
 
getUfsPath() - Method in class alluxio.grpc.Block.Builder
optional string ufs_path = 3;
getUfsPath() - Method in class alluxio.grpc.Block
optional string ufs_path = 3;
getUfsPath() - Method in interface alluxio.grpc.BlockOrBuilder
optional string ufs_path = 3;
getUfsPath() - Method in class alluxio.grpc.File.Builder
optional string ufs_path = 2;
getUfsPath() - Method in class alluxio.grpc.File
optional string ufs_path = 2;
getUfsPath() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsPath = 4;
getUfsPath() - Method in class alluxio.grpc.FileInfo
optional string ufsPath = 4;
getUfsPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsPath = 4;
getUfsPath() - Method in interface alluxio.grpc.FileOrBuilder
optional string ufs_path = 2;
getUfsPath() - Method in class alluxio.grpc.MountPRequest.Builder
the path of the under file system
getUfsPath() - Method in class alluxio.grpc.MountPRequest
the path of the under file system
getUfsPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
the path of the under file system
getUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
the ufs path
getUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest
the ufs path
getUfsPath() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
the ufs path
getUfsPath() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
getUfsPath() - Method in class alluxio.job.plan.persist.PersistConfig
 
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string ufs_path = 1;
getUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string ufs_path = 1;
getUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string ufs_path = 1;
getUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
getUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string ufs_path = 2;
getUfsPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string ufs_path = 2;
getUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
getUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional string ufsPath = 1;
getUfsPath() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional string ufsPath = 1;
getUfsPath() - Method in class alluxio.wire.FileInfo
 
getUfsPath() - Method in class alluxio.worker.grpc.UfsFileWriteRequest
 
getUfsPath() - Method in class alluxio.worker.netty.UfsFileWriteRequest
 
getUfsPath(AlluxioURI) - Method in class alluxio.worker.s3.S3NettyHandler
Gets UFS full path from Alluxio path.
getUfsPathBytes() - Method in class alluxio.grpc.Block.Builder
optional string ufs_path = 3;
getUfsPathBytes() - Method in class alluxio.grpc.Block
optional string ufs_path = 3;
getUfsPathBytes() - Method in interface alluxio.grpc.BlockOrBuilder
optional string ufs_path = 3;
getUfsPathBytes() - Method in class alluxio.grpc.File.Builder
optional string ufs_path = 2;
getUfsPathBytes() - Method in class alluxio.grpc.File
optional string ufs_path = 2;
getUfsPathBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsPath = 4;
getUfsPathBytes() - Method in class alluxio.grpc.FileInfo
optional string ufsPath = 4;
getUfsPathBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsPath = 4;
getUfsPathBytes() - Method in interface alluxio.grpc.FileOrBuilder
optional string ufs_path = 2;
getUfsPathBytes() - Method in class alluxio.grpc.MountPRequest.Builder
the path of the under file system
getUfsPathBytes() - Method in class alluxio.grpc.MountPRequest
the path of the under file system
getUfsPathBytes() - Method in interface alluxio.grpc.MountPRequestOrBuilder
the path of the under file system
getUfsPathBytes() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
the ufs path
getUfsPathBytes() - Method in class alluxio.grpc.UpdateUfsModePRequest
the ufs path
getUfsPathBytes() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
the ufs path
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string ufs_path = 1;
getUfsPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string ufs_path = 1;
getUfsPathBytes() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string ufs_path = 1;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string ufs_path = 2;
getUfsPathBytes() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string ufs_path = 2;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
getUfsPathBytes() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional string ufsPath = 1;
getUfsPathBytes() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional string ufsPath = 1;
getUfsReadOptions() - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptions() - Method in class alluxio.grpc.CopyRequest
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptions() - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptions() - Method in class alluxio.grpc.MoveRequest
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsOrBuilder() - Method in interface alluxio.grpc.CopyRequestOrBuilder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadOptionsOrBuilder() - Method in interface alluxio.grpc.MoveRequestOrBuilder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
getUfsReadSize() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs read size.
getUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
getUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
getUfsReadWorkerLocation() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
getUfsReadWorkerLocationBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
getUfsReadWorkerLocationOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
getUfsReadWorkerLocationOrBuilder() - Method in class alluxio.grpc.OpenFilePOptions
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
getUfsReadWorkerLocationOrBuilder() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
getUfsResource() - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
getUfsStatus() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatus() - Method in class alluxio.grpc.LoadFileFailure
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatus() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatus(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatus(int) - Method in class alluxio.grpc.LoadFileRequest
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatus(int) - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatus() - Method in class alluxio.master.file.contexts.CompleteFileContext
 
getUfsStatus() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
 
getUfsStatus() - Method in class alluxio.master.file.contexts.LoadMetadataContext
 
getUfsStatusBuilder() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusBuilder(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusBuilderList() - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusCount() - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusCount() - Method in class alluxio.grpc.LoadFileRequest
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusCount() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusList() - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusList() - Method in class alluxio.grpc.LoadFileRequest
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusList() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilder() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilder() - Method in class alluxio.grpc.LoadFileFailure
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilder() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilder(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilder(int) - Method in class alluxio.grpc.LoadFileRequest
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilder(int) - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilderList() - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilderList() - Method in class alluxio.grpc.LoadFileRequest
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStatusOrBuilderList() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
getUfsStringLocations(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
getUfsStringLocations(int) - Method in class alluxio.grpc.FileBlockInfo
repeated string ufsStringLocations = 4;
getUfsStringLocations(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
repeated string ufsStringLocations = 4;
getUfsStringLocationsBytes(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
getUfsStringLocationsBytes(int) - Method in class alluxio.grpc.FileBlockInfo
repeated string ufsStringLocations = 4;
getUfsStringLocationsBytes(int) - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
repeated string ufsStringLocations = 4;
getUfsStringLocationsCount() - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
getUfsStringLocationsCount() - Method in class alluxio.grpc.FileBlockInfo
repeated string ufsStringLocations = 4;
getUfsStringLocationsCount() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
repeated string ufsStringLocations = 4;
getUfsStringLocationsList() - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
getUfsStringLocationsList() - Method in class alluxio.grpc.FileBlockInfo
repeated string ufsStringLocations = 4;
getUfsStringLocationsList() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
repeated string ufsStringLocations = 4;
getUfsSyncMetric(long) - Method in class alluxio.master.file.meta.MountTable
 
getUfsSyncPathCache() - Method in class alluxio.master.file.meta.MountTable
 
getUfsType() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsType = 35;
getUfsType() - Method in class alluxio.grpc.FileInfo
optional string ufsType = 35;
getUfsType() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsType = 35;
getUfsType() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
getUfsType() - Method in class alluxio.grpc.MountPointInfo
optional string ufsType = 2;
getUfsType() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional string ufsType = 2;
getUfsType() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs type.
getUfsType() - Method in class alluxio.wire.FileInfo
 
getUfsType() - Method in class alluxio.wire.MountPointInfo
 
getUfsTypeBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsType = 35;
getUfsTypeBytes() - Method in class alluxio.grpc.FileInfo
optional string ufsType = 35;
getUfsTypeBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsType = 35;
getUfsTypeBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
getUfsTypeBytes() - Method in class alluxio.grpc.MountPointInfo
optional string ufsType = 2;
getUfsTypeBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional string ufsType = 2;
getUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
required string ufsUri = 1;
getUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest
required string ufsUri = 1;
getUfsUri() - Method in interface alluxio.grpc.GetMountIdPRequestOrBuilder
required string ufsUri = 1;
getUfsUri() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsUri = 1;
getUfsUri() - Method in class alluxio.grpc.MountPointInfo
optional string ufsUri = 1;
getUfsUri() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional string ufsUri = 1;
getUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
optional string ufsUri = 1;
getUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest
optional string ufsUri = 1;
getUfsUri() - Method in interface alluxio.grpc.ReverseResolvePRequestOrBuilder
optional string ufsUri = 1;
getUfsUri() - Method in class alluxio.master.file.meta.options.MountInfo
 
getUfsUri() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs uri.
getUfsUri() - Method in class alluxio.wire.MountPointInfo
 
getUfsUriBytes() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
required string ufsUri = 1;
getUfsUriBytes() - Method in class alluxio.grpc.GetMountIdPRequest
required string ufsUri = 1;
getUfsUriBytes() - Method in interface alluxio.grpc.GetMountIdPRequestOrBuilder
required string ufsUri = 1;
getUfsUriBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsUri = 1;
getUfsUriBytes() - Method in class alluxio.grpc.MountPointInfo
optional string ufsUri = 1;
getUfsUriBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional string ufsUri = 1;
getUfsUriBytes() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
optional string ufsUri = 1;
getUfsUriBytes() - Method in class alluxio.grpc.ReverseResolvePRequest
optional string ufsUri = 1;
getUfsUriBytes() - Method in interface alluxio.grpc.ReverseResolvePRequestOrBuilder
optional string ufsUri = 1;
getUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsUsedBytes = 4 [default = -1];
getUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo
optional int64 ufsUsedBytes = 4 [default = -1];
getUfsUsedBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional int64 ufsUsedBytes = 4 [default = -1];
getUfsUsedBytes() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs used bytes.
getUfsUsedBytes() - Method in class alluxio.wire.MountPointInfo
 
getUfsWriteSize() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs write size.
getUid(String) - Static method in class alluxio.fuse.AlluxioFuseUtils
Retrieves the uid of the given user.
getUid() - Method in interface alluxio.fuse.auth.AuthPolicy
 
getUid(String) - Method in interface alluxio.fuse.auth.AuthPolicy
Gets the uid based on the auth policy and file owner.
getUid() - Method in class alluxio.fuse.auth.CustomAuthPolicy
 
getUid() - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
getUid() - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
 
getUid(String) - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
 
getUid() - Method in class alluxio.fuse.file.CreateFileStatus
 
getUMask(String) - Static method in class alluxio.util.ModeUtils
Gets the file / directory creation umask.
getUncaughtExceptionHandler() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
getUnchecked() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool unchecked = 3;
getUnchecked() - Method in class alluxio.grpc.DeletePOptions
optional bool unchecked = 3;
getUnchecked() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool unchecked = 3;
getUnderFileSystem() - Method in class alluxio.underfs.UnderFileSystemWithLogging
This is only used in the test.
getUnderFileSystem(String) - Method in class alluxio.worker.dora.PagedDoraWorker
 
getUnderFileSystem() - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
getUnderFSType() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getUnderFSType() - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.adl.AdlUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.cosn.CosnUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.ozone.OzoneUnderFileSystem
 
getUnderFSType() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
getUnderFSType() - Method in interface alluxio.underfs.UnderFileSystem
Returns the name of the under filesystem implementation.
getUnderFSType() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getUnderFSType() - Method in class alluxio.underfs.wasb.WasbUnderFileSystem
 
getUnderlyingFileSystem() - Method in class alluxio.client.file.DelegatingFileSystem
 
getUnderlyingJournalContext() - Method in class alluxio.master.journal.FileSystemMergeJournalContext
 
getUnderStorageType() - Method in class alluxio.client.file.options.OutStreamOptions
 
getUnderStorageType() - Method in enum alluxio.client.WriteType
 
getUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 unfinishedTasks = 7;
getUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth
optional int32 unfinishedTasks = 7;
getUnfinishedTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int32 unfinishedTasks = 7;
getUnfinishedTasks() - Method in class alluxio.job.wire.JobWorkerHealth
 
getUniqueBlockCount() - Method in interface alluxio.master.block.BlockMaster
 
getUniqueBlockCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getUniqueBlockCount() - Method in class alluxio.wire.MasterWebUIOverview
Gets unique block count.
getUnixGroups(String) - Static method in class alluxio.util.CommonUtils
Gets the current user's group list from Unix by running the command 'groups' NOTE.
getUnixMountInfo() - Static method in class alluxio.util.ShellUtils
Gets system mount information.
getUnknownFields() - Method in class alluxio.grpc.ActionInfo
 
getUnknownFields() - Method in class alluxio.grpc.AddPolicyPOptions
 
getUnknownFields() - Method in class alluxio.grpc.AddPolicyPRequest
 
getUnknownFields() - Method in class alluxio.grpc.AddPolicyPResponse
 
getUnknownFields() - Method in class alluxio.grpc.AddQuorumServerRequest
 
getUnknownFields() - Method in class alluxio.grpc.AsyncCacheRequest
 
getUnknownFields() - Method in class alluxio.grpc.AsyncCacheResponse
 
getUnknownFields() - Method in class alluxio.grpc.BackupPOptions
 
getUnknownFields() - Method in class alluxio.grpc.BackupPRequest
 
getUnknownFields() - Method in class alluxio.grpc.BackupPStatus
 
getUnknownFields() - Method in class alluxio.grpc.BackupStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.Block
 
getUnknownFields() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
getUnknownFields() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
getUnknownFields() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
getUnknownFields() - Method in class alluxio.grpc.BlockIdList
 
getUnknownFields() - Method in class alluxio.grpc.BlockInfo
 
getUnknownFields() - Method in class alluxio.grpc.BlockLocation
 
getUnknownFields() - Method in class alluxio.grpc.BlockMasterInfo
 
getUnknownFields() - Method in class alluxio.grpc.BlockStatus
 
getUnknownFields() - Method in class alluxio.grpc.BlockStoreLocationProto
 
getUnknownFields() - Method in class alluxio.grpc.BuildVersion
 
getUnknownFields() - Method in class alluxio.grpc.CacheRequest
 
getUnknownFields() - Method in class alluxio.grpc.CacheResponse
 
getUnknownFields() - Method in class alluxio.grpc.CancelPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CancelPRequest
 
getUnknownFields() - Method in class alluxio.grpc.CancelPResponse
 
getUnknownFields() - Method in class alluxio.grpc.CancelTaskCommand
 
getUnknownFields() - Method in class alluxio.grpc.CheckAccessPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CheckAccessPRequest
 
getUnknownFields() - Method in class alluxio.grpc.CheckAccessPResponse
 
getUnknownFields() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
getUnknownFields() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
getUnknownFields() - Method in class alluxio.grpc.CheckpointPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CheckpointPResponse
 
getUnknownFields() - Method in class alluxio.grpc.CheckRequest
 
getUnknownFields() - Method in class alluxio.grpc.CheckResponse
 
getUnknownFields() - Method in class alluxio.grpc.Chunk
 
getUnknownFields() - Method in class alluxio.grpc.ClearMetricsPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ClearMetricsPResponse
 
getUnknownFields() - Method in class alluxio.grpc.ClearMetricsRequest
 
getUnknownFields() - Method in class alluxio.grpc.ClearMetricsResponse
 
getUnknownFields() - Method in class alluxio.grpc.ClientMetrics
 
getUnknownFields() - Method in class alluxio.grpc.CmdProgress
 
getUnknownFields() - Method in class alluxio.grpc.CmdStatusBlock
 
getUnknownFields() - Method in class alluxio.grpc.CmdSummary
 
getUnknownFields() - Method in class alluxio.grpc.Command
 
getUnknownFields() - Method in class alluxio.grpc.CommitBlockPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CommitBlockPRequest
 
getUnknownFields() - Method in class alluxio.grpc.CommitBlockPResponse
 
getUnknownFields() - Method in class alluxio.grpc.CompleteFilePOptions
 
getUnknownFields() - Method in class alluxio.grpc.CompleteFilePRequest
 
getUnknownFields() - Method in class alluxio.grpc.CompleteFilePResponse
 
getUnknownFields() - Method in class alluxio.grpc.ConfigCheckReport
 
getUnknownFields() - Method in class alluxio.grpc.ConfigProperties
 
getUnknownFields() - Method in class alluxio.grpc.ConfigProperty
 
getUnknownFields() - Method in class alluxio.grpc.CopyJobPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CopyRequest
 
getUnknownFields() - Method in class alluxio.grpc.CopyResponse
 
getUnknownFields() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
getUnknownFields() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
getUnknownFields() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
getUnknownFields() - Method in class alluxio.grpc.CreateFilePOptions
 
getUnknownFields() - Method in class alluxio.grpc.CreateFilePRequest
 
getUnknownFields() - Method in class alluxio.grpc.CreateFilePResponse
 
getUnknownFields() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
getUnknownFields() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
getUnknownFields() - Method in class alluxio.grpc.DeletePOptions
 
getUnknownFields() - Method in class alluxio.grpc.DeletePRequest
 
getUnknownFields() - Method in class alluxio.grpc.DeletePResponse
 
getUnknownFields() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.ErrorInfo
 
getUnknownFields() - Method in class alluxio.grpc.ExistsPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ExistsPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ExistsPResponse
 
getUnknownFields() - Method in class alluxio.grpc.File
 
getUnknownFields() - Method in class alluxio.grpc.FileBlockInfo
 
getUnknownFields() - Method in class alluxio.grpc.FileFailure
 
getUnknownFields() - Method in class alluxio.grpc.FileInfo
 
getUnknownFields() - Method in class alluxio.grpc.FileSystemCommand
 
getUnknownFields() - Method in class alluxio.grpc.FileSystemCommandOptions
 
getUnknownFields() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
getUnknownFields() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
getUnknownFields() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
getUnknownFields() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
getUnknownFields() - Method in class alluxio.grpc.FreePOptions
 
getUnknownFields() - Method in class alluxio.grpc.FreePRequest
 
getUnknownFields() - Method in class alluxio.grpc.FreePResponse
 
getUnknownFields() - Method in class alluxio.grpc.FreeWorkerRequest
 
getUnknownFields() - Method in class alluxio.grpc.FreeWorkerResponse
 
getUnknownFields() - Method in class alluxio.grpc.FsOpPId
 
getUnknownFields() - Method in class alluxio.grpc.GetActionInfoOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetActionInfoRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetActionInfoResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetCmdStatusResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetConfigHashPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetConfigHashPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetConfigReportPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetConfigReportPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetConfigurationPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetConfigurationPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetFileInfoPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetFileInfoPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetFileInfoPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetFilePathPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetFilePathPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetJobProgressPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetJobProgressPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetJobStatusPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetJobStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetJobStatusPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetMasterIdPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetMasterIdPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetMasterIdPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetMetricsPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetMetricsPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetMountIdPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetMountIdPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetMountTablePRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetMountTablePResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetNodeStatePRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetNodeStatePResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetStatusPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetStatusPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
getUnknownFields() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
getUnknownFields() - Method in class alluxio.grpc.InconsistentProperties
 
getUnknownFields() - Method in class alluxio.grpc.InconsistentProperty
 
getUnknownFields() - Method in class alluxio.grpc.InconsistentPropertyValues
 
getUnknownFields() - Method in class alluxio.grpc.JobCommand
 
getUnknownFields() - Method in class alluxio.grpc.JobDescription
 
getUnknownFields() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
getUnknownFields() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
getUnknownFields() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
getUnknownFields() - Method in class alluxio.grpc.JobInfo
 
getUnknownFields() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
getUnknownFields() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
getUnknownFields() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
getUnknownFields() - Method in class alluxio.grpc.JobMasterStatus
 
getUnknownFields() - Method in class alluxio.grpc.JobProgress
 
getUnknownFields() - Method in class alluxio.grpc.JobProgressPOptions
 
getUnknownFields() - Method in class alluxio.grpc.JobServiceSummary
 
getUnknownFields() - Method in class alluxio.grpc.JobStatusBlock
 
getUnknownFields() - Method in class alluxio.grpc.JobUnused
 
getUnknownFields() - Method in class alluxio.grpc.JobWorkerHealth
 
getUnknownFields() - Method in class alluxio.grpc.JournalQueryRequest
 
getUnknownFields() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ListAllPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ListAllPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ListAllPResponse
 
getUnknownFields() - Method in class alluxio.grpc.ListPolicyPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ListPolicyPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ListPolicyPResponse
 
getUnknownFields() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ListStatusPResponse
 
getUnknownFields() - Method in class alluxio.grpc.LoadFileFailure
 
getUnknownFields() - Method in class alluxio.grpc.LoadFileRequest
 
getUnknownFields() - Method in class alluxio.grpc.LoadFileResponse
 
getUnknownFields() - Method in class alluxio.grpc.LoadJobPOptions
 
getUnknownFields() - Method in class alluxio.grpc.LoadMetadataPOptions
 
getUnknownFields() - Method in class alluxio.grpc.LoadRequest
 
getUnknownFields() - Method in class alluxio.grpc.LoadResponse
 
getUnknownFields() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
getUnknownFields() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
getUnknownFields() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
getUnknownFields() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
getUnknownFields() - Method in class alluxio.grpc.MasterInfo
 
getUnknownFields() - Method in class alluxio.grpc.MasterVersion
 
getUnknownFields() - Method in class alluxio.grpc.MessagingRequestHeader
 
getUnknownFields() - Method in class alluxio.grpc.MessagingResponseHeader
 
getUnknownFields() - Method in class alluxio.grpc.Metric
 
getUnknownFields() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
getUnknownFields() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
getUnknownFields() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
getUnknownFields() - Method in class alluxio.grpc.MetricValue
 
getUnknownFields() - Method in class alluxio.grpc.MountPointInfo
 
getUnknownFields() - Method in class alluxio.grpc.MountPOptions
 
getUnknownFields() - Method in class alluxio.grpc.MountPRequest
 
getUnknownFields() - Method in class alluxio.grpc.MountPResponse
 
getUnknownFields() - Method in class alluxio.grpc.MoveBlockRequest
 
getUnknownFields() - Method in class alluxio.grpc.MoveBlockResponse
 
getUnknownFields() - Method in class alluxio.grpc.MoveJobPOptions
 
getUnknownFields() - Method in class alluxio.grpc.MoveRequest
 
getUnknownFields() - Method in class alluxio.grpc.MoveResponse
 
getUnknownFields() - Method in class alluxio.grpc.NeedsSyncRequest
 
getUnknownFields() - Method in class alluxio.grpc.NeedsSyncResponse
 
getUnknownFields() - Method in class alluxio.grpc.NetAddress
 
getUnknownFields() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
getUnknownFields() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
getUnknownFields() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
getUnknownFields() - Method in class alluxio.grpc.OpenFilePOptions
 
getUnknownFields() - Method in class alluxio.grpc.PAcl
 
getUnknownFields() - Method in class alluxio.grpc.PAclEntry
 
getUnknownFields() - Method in class alluxio.grpc.PersistCommandOptions
 
getUnknownFields() - Method in class alluxio.grpc.PersistFile
 
getUnknownFields() - Method in class alluxio.grpc.PMode
 
getUnknownFields() - Method in class alluxio.grpc.PolicyInfo
 
getUnknownFields() - Method in class alluxio.grpc.PolicyStatus
 
getUnknownFields() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
getUnknownFields() - Method in class alluxio.grpc.ProxyStatus
 
getUnknownFields() - Method in class alluxio.grpc.QuorumServerInfo
 
getUnknownFields() - Method in class alluxio.grpc.ReadRequest
 
getUnknownFields() - Method in class alluxio.grpc.ReadResponse
 
getUnknownFields() - Method in class alluxio.grpc.RegisterCommand
 
getUnknownFields() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RegisterMasterPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RegisterMasterPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RegisterMasterPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RemoveBlockRequest
 
getUnknownFields() - Method in class alluxio.grpc.RemoveBlockResponse
 
getUnknownFields() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RemovePolicyPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RemovePolicyPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RemovePolicyPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RenamePOptions
 
getUnknownFields() - Method in class alluxio.grpc.RenamePRequest
 
getUnknownFields() - Method in class alluxio.grpc.RenamePResponse
 
getUnknownFields() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
getUnknownFields() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
getUnknownFields() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RetryInfo
 
getUnknownFields() - Method in class alluxio.grpc.ReverseResolvePRequest
 
getUnknownFields() - Method in class alluxio.grpc.ReverseResolvePResponse
 
getUnknownFields() - Method in class alluxio.grpc.Route
 
getUnknownFields() - Method in class alluxio.grpc.RouteFailure
 
getUnknownFields() - Method in class alluxio.grpc.RunPOptions
 
getUnknownFields() - Method in class alluxio.grpc.RunPRequest
 
getUnknownFields() - Method in class alluxio.grpc.RunPResponse
 
getUnknownFields() - Method in class alluxio.grpc.RunTaskCommand
 
getUnknownFields() - Method in class alluxio.grpc.S3SyntaxOptions
 
getUnknownFields() - Method in class alluxio.grpc.SaslMessage
 
getUnknownFields() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
getUnknownFields() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
getUnknownFields() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
getUnknownFields() - Method in class alluxio.grpc.SetAclPOptions
 
getUnknownFields() - Method in class alluxio.grpc.SetAclPRequest
 
getUnknownFields() - Method in class alluxio.grpc.SetAclPResponse
 
getUnknownFields() - Method in class alluxio.grpc.SetAttributePOptions
 
getUnknownFields() - Method in class alluxio.grpc.SetAttributePRequest
 
getUnknownFields() - Method in class alluxio.grpc.SetAttributePResponse
 
getUnknownFields() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
getUnknownFields() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
getUnknownFields() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
getUnknownFields() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
getUnknownFields() - Method in class alluxio.grpc.SnapshotData
 
getUnknownFields() - Method in class alluxio.grpc.SnapshotMetadata
 
getUnknownFields() - Method in class alluxio.grpc.StatusSummary
 
getUnknownFields() - Method in class alluxio.grpc.StopJobPRequest
 
getUnknownFields() - Method in class alluxio.grpc.StopJobPResponse
 
getUnknownFields() - Method in class alluxio.grpc.StorageList
 
getUnknownFields() - Method in class alluxio.grpc.SubmitJobPRequest
 
getUnknownFields() - Method in class alluxio.grpc.SubmitJobPResponse
 
getUnknownFields() - Method in class alluxio.grpc.SubmitOptions
 
getUnknownFields() - Method in class alluxio.grpc.SubmitRequest
 
getUnknownFields() - Method in class alluxio.grpc.SubmitResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.AllOrNoneSet
 
getUnknownFields() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
getUnknownFields() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
getUnknownFields() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
getUnknownFields() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
getUnknownFields() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
getUnknownFields() - Method in class alluxio.grpc.table.Constraint
 
getUnknownFields() - Method in class alluxio.grpc.table.Database
 
getUnknownFields() - Method in class alluxio.grpc.table.Date
 
getUnknownFields() - Method in class alluxio.grpc.table.DateColumnStatsData
 
getUnknownFields() - Method in class alluxio.grpc.table.Decimal
 
getUnknownFields() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
getUnknownFields() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.Domain
 
getUnknownFields() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
getUnknownFields() - Method in class alluxio.grpc.table.EquatableValueSet
 
getUnknownFields() - Method in class alluxio.grpc.table.FieldSchema
 
getUnknownFields() - Method in class alluxio.grpc.table.FileStatistics
 
getUnknownFields() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.GetTablePRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.GetTablePResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.Layout
 
getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.Storage
 
getUnknownFields() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
getUnknownFields() - Method in class alluxio.grpc.table.LayoutSpec
 
getUnknownFields() - Method in class alluxio.grpc.table.LongColumnStatsData
 
getUnknownFields() - Method in class alluxio.grpc.table.Partition
 
getUnknownFields() - Method in class alluxio.grpc.table.PartitionSpec
 
getUnknownFields() - Method in class alluxio.grpc.table.Range
 
getUnknownFields() - Method in class alluxio.grpc.table.RangeSet
 
getUnknownFields() - Method in class alluxio.grpc.table.ReadTablePRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.ReadTablePResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.Schema
 
getUnknownFields() - Method in class alluxio.grpc.table.StringColumnStatsData
 
getUnknownFields() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.SyncStatus
 
getUnknownFields() - Method in class alluxio.grpc.table.TableInfo
 
getUnknownFields() - Method in class alluxio.grpc.table.Transformation
 
getUnknownFields() - Method in class alluxio.grpc.table.TransformJobInfo
 
getUnknownFields() - Method in class alluxio.grpc.table.TransformTablePRequest
 
getUnknownFields() - Method in class alluxio.grpc.table.TransformTablePResponse
 
getUnknownFields() - Method in class alluxio.grpc.table.Value
 
getUnknownFields() - Method in class alluxio.grpc.TierList
 
getUnknownFields() - Method in class alluxio.grpc.TransferLeaderMessage
 
getUnknownFields() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
getUnknownFields() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
getUnknownFields() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
getUnknownFields() - Method in class alluxio.grpc.TransportMessage
 
getUnknownFields() - Method in class alluxio.grpc.TriggerPolicyRequest
 
getUnknownFields() - Method in class alluxio.grpc.TriggerPolicyResponse
 
getUnknownFields() - Method in class alluxio.grpc.UfsFileStatus
 
getUnknownFields() - Method in class alluxio.grpc.UfsInfo
 
getUnknownFields() - Method in class alluxio.grpc.UfsReadOptions
 
getUnknownFields() - Method in class alluxio.grpc.UfsStatus
 
getUnknownFields() - Method in class alluxio.grpc.UnmountPOptions
 
getUnknownFields() - Method in class alluxio.grpc.UnmountPRequest
 
getUnknownFields() - Method in class alluxio.grpc.UnmountPResponse
 
getUnknownFields() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
getUnknownFields() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
getUnknownFields() - Method in class alluxio.grpc.UpdateMountPRequest
 
getUnknownFields() - Method in class alluxio.grpc.UpdateMountPResponse
 
getUnknownFields() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
getUnknownFields() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
getUnknownFields() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
getUnknownFields() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
getUnknownFields() - Method in class alluxio.grpc.WorkerIdentity
 
getUnknownFields() - Method in class alluxio.grpc.WorkerInfo
 
getUnknownFields() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
getUnknownFields() - Method in class alluxio.grpc.WorkerNetAddress
 
getUnknownFields() - Method in class alluxio.grpc.WriteOptions
 
getUnknownFields() - Method in class alluxio.grpc.WriteRequest
 
getUnknownFields() - Method in class alluxio.grpc.WriteRequestCommand
 
getUnknownFields() - Method in class alluxio.grpc.WriteResponse
 
getUnknownFields() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
getUnknownFields() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.Response
 
getUnknownFields() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
getUnknownFields() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.RenameEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.SetAclEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.StringPairEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Job.FileFilter
 
getUnknownFields() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
getUnknownFields() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
getUnknownFields() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
getUnknownFields() - Method in class alluxio.proto.meta.Block.BlockLocation
 
getUnknownFields() - Method in class alluxio.proto.meta.Block.BlockMeta
 
getUnknownFields() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
getUnknownFields() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
getUnknownFields() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
getUnknownFields() - Method in class alluxio.proto.shared.Acl.AclActions
 
getUnknownFields() - Method in class alluxio.proto.shared.Acl.AclEntry
 
getUnknownFields() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
getUnmodifiableView() - Method in class alluxio.master.file.state.DirectoryId
 
getUnmountMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getUnrecognizedOptions() - Method in class alluxio.fuse.options.MountOptions
Gets options that are neither an Alluxio property, nor an option special to Alluxio Fuse.
getUnscaled() - Method in class alluxio.grpc.table.Decimal.Builder
required bytes unscaled = 2;
getUnscaled() - Method in class alluxio.grpc.table.Decimal
required bytes unscaled = 2;
getUnscaled() - Method in interface alluxio.grpc.table.DecimalOrBuilder
required bytes unscaled = 2;
getUnused0(int) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
getUnused0(int) - Method in class alluxio.grpc.JobInfo
Around for backwards compatibility
getUnused0(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
Around for backwards compatibility
getUnused0Builder(int) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
getUnused0BuilderList() - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
getUnused0Count() - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
getUnused0Count() - Method in class alluxio.grpc.JobInfo
Around for backwards compatibility
getUnused0Count() - Method in interface alluxio.grpc.JobInfoOrBuilder
Around for backwards compatibility
getUnused0List() - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
getUnused0List() - Method in class alluxio.grpc.JobInfo
Around for backwards compatibility
getUnused0List() - Method in interface alluxio.grpc.JobInfoOrBuilder
Around for backwards compatibility
getUnused0OrBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
getUnused0OrBuilder(int) - Method in class alluxio.grpc.JobInfo
Around for backwards compatibility
getUnused0OrBuilder(int) - Method in interface alluxio.grpc.JobInfoOrBuilder
Around for backwards compatibility
getUnused0OrBuilderList() - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
getUnused0OrBuilderList() - Method in class alluxio.grpc.JobInfo
Around for backwards compatibility
getUnused0OrBuilderList() - Method in interface alluxio.grpc.JobInfoOrBuilder
Around for backwards compatibility
getUnused1() - Method in class alluxio.grpc.JobInfo.Builder
formerly result
getUnused1() - Method in class alluxio.grpc.JobInfo
formerly result
getUnused1() - Method in interface alluxio.grpc.JobInfoOrBuilder
formerly result
getUnused1Bytes() - Method in class alluxio.grpc.JobInfo.Builder
formerly result
getUnused1Bytes() - Method in class alluxio.grpc.JobInfo
formerly result
getUnused1Bytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
formerly result
getUpdateCheck() - Method in class alluxio.fuse.options.FuseCliOptions
 
getUpdateConfigurationMethod() - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
getUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
getUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
getUpdateInode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
getUpdateInodeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
getUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
getUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
getUpdateInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
getUpdateInodeDirectoryBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
getUpdateInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
getUpdateInodeDirectoryOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
getUpdateInodeDirectoryOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
getUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
getUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
getUpdateInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
getUpdateInodeFileBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
getUpdateInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
getUpdateInodeFileOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
getUpdateInodeFileOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
getUpdateInodeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
getUpdateInodeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
getUpdateInodeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
getUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional bool updateLastAccessTime = 4 [default = true];
getUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions
optional bool updateLastAccessTime = 4 [default = true];
getUpdateLastAccessTime() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional bool updateLastAccessTime = 4 [default = true];
getUpdateMountMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool updateTimestamps = 4 [default = true];
getUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions
optional bool updateTimestamps = 4 [default = true];
getUpdateTimestamps() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional bool updateTimestamps = 4 [default = true];
getUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsMode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeMethod() - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
getUpdateUfsModeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeOrBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUpdateUfsModeOrBuilder() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
getUploadId() - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
getUploadId() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
 
getUploadId() - Method in class alluxio.proxy.s3.ListPartsResult
 
getUploadPath() - Method in class alluxio.underfs.s3a.S3AOutputStream
 
getUploads() - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
 
getUploadSnapshotMethod() - Static method in class alluxio.grpc.RaftJournalServiceGrpc
 
getUptime() - Method in class alluxio.util.webui.UIWorkerInfo
Gets uptime.
getUptime() - Method in class alluxio.wire.MasterWebUIOverview
Gets uptime.
getUptimeClockTime() - Method in class alluxio.util.webui.NodeInfo
Gets uptime clock time.
getUptimeDuration() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get time running.
getUpTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 upTimeMs = 6;
getUpTimeMs() - Method in class alluxio.grpc.MasterInfo
optional int64 upTimeMs = 6;
getUpTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int64 upTimeMs = 6;
getUptimeMs() - Method in class alluxio.master.MasterProcess
 
getUptimeMs() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getUptimeMs() - Method in interface alluxio.master.meta.MetaMaster
 
getUptimeMs() - Method in class alluxio.proxy.AlluxioProxyProcess
 
getUptimeMs() - Method in interface alluxio.proxy.ProxyProcess
 
getUptimeMs() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getUptimeMs() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
getUptimeMs() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getUptimeMs() - Method in interface alluxio.worker.JobWorkerProcess
 
getUptimeMs() - Method in interface alluxio.worker.WorkerProcess
 
getUri() - Method in class alluxio.grpc.UfsInfo.Builder
optional string uri = 1;
getUri() - Method in class alluxio.grpc.UfsInfo
optional string uri = 1;
getUri() - Method in interface alluxio.grpc.UfsInfoOrBuilder
optional string uri = 1;
getUri() - Method in class alluxio.hadoop.AbstractFileSystem
 
getUri() - Method in class alluxio.hadoop.LocalCacheFileSystem
 
getUri() - Method in class alluxio.master.file.meta.LockedInodePath
 
getUri() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
getUri() - Method in class alluxio.master.file.meta.MountTable.ReverseResolution
 
getUri() - Method in class alluxio.master.file.PersistJob
 
getUri() - Method in class alluxio.master.LocalAlluxioMaster
 
getUri() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getUri() - Method in class alluxio.wire.UfsInfo
 
getUriBytes() - Method in class alluxio.grpc.UfsInfo.Builder
optional string uri = 1;
getUriBytes() - Method in class alluxio.grpc.UfsInfo
optional string uri = 1;
getUriBytes() - Method in interface alluxio.grpc.UfsInfoOrBuilder
optional string uri = 1;
getUriStatus() - Method in class alluxio.hadoop.AlluxioFileStatus
get uri status.
getUriValidationEnabled() - Method in class alluxio.client.file.FileSystemContext
 
getUriValidationEnabled() - Method in class alluxio.ClientContext
 
getUsage() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
 
getUsage() - Method in class alluxio.cli.bundler.command.CollectConfigCommand
 
getUsage() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
 
getUsage() - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
 
getUsage() - Method in class alluxio.cli.bundler.command.CollectLogCommand
 
getUsage() - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
 
getUsage() - Method in interface alluxio.cli.Command
 
getUsage() - Method in class alluxio.cli.command.metadatacache.DropAllCommand
 
getUsage() - Method in class alluxio.cli.command.metadatacache.DropCommand
 
getUsage() - Method in class alluxio.cli.command.metadatacache.SizeCommand
 
getUsage() - Method in class alluxio.cli.command.MetadataCacheCommand
 
getUsage() - Method in class alluxio.cli.extensions.command.InstallCommand
 
getUsage() - Method in class alluxio.cli.extensions.command.LsCommand
 
getUsage() - Method in class alluxio.cli.extensions.command.UninstallCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CatCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CheckCachedCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChecksumCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChgrpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChmodCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ChownCommand
 
getUsage() - Method in class alluxio.cli.fs.command.ConsistentHashCommand
 
getUsage() - Method in class alluxio.cli.fs.command.CpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.FreeCommand
 
getUsage() - Method in class alluxio.cli.fs.command.HeadCommand
 
getUsage() - Method in class alluxio.cli.fs.command.HelpCommand
 
getUsage() - Method in class alluxio.cli.fs.command.LoadCommand
 
getUsage() - Method in class alluxio.cli.fs.command.LocationCommand
 
getUsage() - Method in class alluxio.cli.fs.command.LsCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MkdirCommand
 
getUsage() - Method in class alluxio.cli.fs.command.MvCommand
 
getUsage() - Method in class alluxio.cli.fs.command.RmCommand
 
getUsage() - Method in class alluxio.cli.fs.command.StatCommand
 
getUsage() - Method in class alluxio.cli.fs.command.TailCommand
 
getUsage() - Method in class alluxio.cli.fs.command.TestCommand
 
getUsage() - Method in class alluxio.cli.fs.command.TouchCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.JournalCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.MetricsCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.NodesCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
getUsage() - Method in class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
 
getUsage() - Method in interface alluxio.client.file.cache.CacheManager
 
getUsage() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
getUsage() - Method in interface alluxio.client.file.cache.CacheStatus
Gets cache usage.
getUsage() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
getUsage() - Method in class alluxio.client.file.cache.LocalCacheManager
 
getUsage() - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
getUsage() - Method in class alluxio.client.file.cache.QuotaPageMetaStore
 
getUsage() - Method in class alluxio.client.file.cache.store.LocalPageStoreDir
 
getUsage() - Method in class alluxio.client.file.cache.store.MemoryPageStoreDir
 
getUsageOnTiers() - Method in class alluxio.wire.WorkerWebUIOverview
Gets usage on tiers.
getUsed() - Method in class alluxio.wire.Capacity
 
getUsedBytes() - Method in interface alluxio.client.block.BlockMasterClient
Gets the total amount of used space in bytes, on all the tiers of all the workers.
getUsedBytes() - Method in class alluxio.client.block.BlockStoreClient
Gets the used bytes of Alluxio's BlockStore.
getUsedBytes() - Method in class alluxio.client.block.BlockWorkerInfo
 
getUsedBytes() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getUsedBytes(GetUsedBytesPOptions, StreamObserver<GetUsedBytesPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns the used storage (in bytes).
getUsedBytes(GetUsedBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns the used storage (in bytes).
getUsedBytes(GetUsedBytesPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns the used storage (in bytes).
getUsedBytes(GetUsedBytesPOptions, StreamObserver<GetUsedBytesPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns the used storage (in bytes).
getUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 usedBytes = 6;
getUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo
optional int64 usedBytes = 6;
getUsedBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int64 usedBytes = 6;
getUsedBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 usedBytes = 6;
getUsedBytes() - Method in class alluxio.grpc.WorkerInfo
optional int64 usedBytes = 6;
getUsedBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 usedBytes = 6;
getUsedBytes() - Method in interface alluxio.master.block.BlockMaster
 
getUsedBytes(GetUsedBytesPOptions, StreamObserver<GetUsedBytesPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getUsedBytes() - Method in class alluxio.master.block.DefaultBlockMaster
 
getUsedBytes() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
getUsedBytes() - Method in class alluxio.util.webui.UIStorageDir
Gets used bytes.
getUsedBytes() - Method in class alluxio.util.webui.UIUsageOnTier
Gets used bytes.
getUsedBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getUsedBytes() - Method in class alluxio.wire.JournalDiskInfo
 
getUsedBytes() - Method in class alluxio.wire.WorkerInfo
 
getUsedBytes() - Method in class alluxio.wire.WorkerWebUIOverview
Gets used bytes.
getUsedBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytes() - Method in class alluxio.worker.block.BlockWorkerMetrics
 
getUsedBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the space used in bytes on the target tier
getUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest
the space used in bytes on the target tier
getUsedBytesOnTier() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the space used in bytes on the target tier
getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
Deprecated.
getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockHeartbeatPRequest
Deprecated.
getUsedBytesOnTiers() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
Deprecated.
getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo.Builder
Deprecated.
getUsedBytesOnTiers() - Method in class alluxio.grpc.BlockMasterInfo
Deprecated.
getUsedBytesOnTiers() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
Deprecated.
getUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
Deprecated.
getUsedBytesOnTiers() - Method in class alluxio.grpc.RegisterWorkerPRequest
Deprecated.
getUsedBytesOnTiers() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
Deprecated.
getUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo.Builder
Deprecated.
getUsedBytesOnTiers() - Method in class alluxio.grpc.WorkerInfo
Deprecated.
getUsedBytesOnTiers() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
Deprecated.
getUsedBytesOnTiers() - Method in interface alluxio.master.block.BlockMaster
 
getUsedBytesOnTiers() - Method in class alluxio.master.block.DefaultBlockMaster
 
getUsedBytesOnTiers() - Method in class alluxio.master.block.meta.MasterWorkerInfo
getUsedBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getUsedBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getUsedBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnTiers() - Method in class alluxio.worker.block.BlockWorkerMetrics
 
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of space used in bytes on all tiers
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.BlockMasterInfo
 
getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of used bytes on each tier
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo.Builder
 
getUsedBytesOnTiersCount() - Method in class alluxio.grpc.WorkerInfo
 
getUsedBytesOnTiersCount() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of space used in bytes on all tiers
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of space used in bytes on all tiers
getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of space used in bytes on all tiers
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of used bytes on each tier
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of used bytes on each tier
getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of used bytes on each tier
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersMap() - Method in class alluxio.grpc.WorkerInfo
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersMap() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of space used in bytes on all tiers
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of space used in bytes on all tiers
getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of space used in bytes on all tiers
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of used bytes on each tier
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of used bytes on each tier
getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of used bytes on each tier
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersOrDefault(String, long) - Method in class alluxio.grpc.WorkerInfo
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersOrDefault(String, long) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of space used in bytes on all tiers
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest
the map of space used in bytes on all tiers
getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the map of space used in bytes on all tiers
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.BlockMasterInfo
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
map<string, int64> usedBytesOnTiers = 7;
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of used bytes on each tier
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.RegisterWorkerPRequest
the map of used bytes on each tier
getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the map of used bytes on each tier
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersOrThrow(String) - Method in class alluxio.grpc.WorkerInfo
map<string, int64> usedBytesOnTiers = 9;
getUsedBytesOnTiersOrThrow(String) - Method in interface alluxio.grpc.WorkerInfoOrBuilder
map<string, int64> usedBytesOnTiers = 9;
GetUsedBytesPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetUsedBytesPOptions
GetUsedBytesPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetUsedBytesPOptions
GetUsedBytesPOptionsOrBuilder - Interface in alluxio.grpc
 
GetUsedBytesPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetUsedBytesPResponse
GetUsedBytesPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetUsedBytesPResponse
GetUsedBytesPResponseOrBuilder - Interface in alluxio.grpc
 
getUsedCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets used capacity.
getUsedCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets used capacity.
getUsedCapacityOnTiers() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get used capacity by tiers.
getUsedMemory() - Method in class alluxio.util.webui.NodeInfo
Gets used memory.
getUsedSpacePercent() - Method in class alluxio.util.webui.NodeInfo
Gets used space percent.
getUsedSpacePercent() - Method in class alluxio.util.webui.StorageTierInfo
Gets used space percent.
getUsedThroughput(Meter) - Method in class alluxio.underfs.UfsIOManager
Get used throughput.
getUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool useMultipartUpload = 17;
getUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions
optional bool useMultipartUpload = 17;
getUseMultipartUpload() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool useMultipartUpload = 17;
getUser() - Method in class alluxio.grpc.UfsReadOptions.Builder
optional string user = 4;
getUser() - Method in class alluxio.grpc.UfsReadOptions
optional string user = 4;
getUser() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
optional string user = 4;
getUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
getUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
The client does not need to set this.
getUser() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
The client does not need to set this.
getUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional string user = 6;
getUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional string user = 6;
getUser() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional string user = 6;
getUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional string user = 5;
getUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional string user = 5;
getUser() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional string user = 5;
getUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional string user = 6;
getUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional string user = 6;
getUser() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional string user = 6;
getUser() - Method in class alluxio.proxy.s3.S3Handler
Get the user name of this request.
getUser(String, ContainerRequestContext) - Static method in class alluxio.proxy.s3.S3RestUtils
Get username from header info.
getUser(String, HttpServletRequest) - Static method in class alluxio.proxy.s3.S3RestUtils
Get username from header info from HttpServletRequest.
getUser(HttpRequest) - Static method in class alluxio.s3.NettyRestUtils
Get username from header info from FullHttpRequest.
getUser() - Method in class alluxio.security.user.BaseUserState
 
getUser() - Method in interface alluxio.security.user.UserState
Returns the User object for this user.
getUser() - Method in class alluxio.worker.s3.S3NettyHandler
Get the user name of this request.
getUserActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActions(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsCount() - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsCount() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsList() - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsOrBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsOrBuilder(int) - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsOrBuilderList() - Method in class alluxio.proto.shared.Acl.AccessControlList
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserActionsOrBuilderList() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
getUserAgentString(String, List<String>) - Static method in class alluxio.check.UpdateCheck
 
getUserBytes() - Method in class alluxio.grpc.UfsReadOptions.Builder
optional string user = 4;
getUserBytes() - Method in class alluxio.grpc.UfsReadOptions
optional string user = 4;
getUserBytes() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
optional string user = 4;
getUserBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
getUserBytes() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
The client does not need to set this.
getUserBytes() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
The client does not need to set this.
getUserBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional string user = 6;
getUserBytes() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional string user = 6;
getUserBytes() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional string user = 6;
getUserBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional string user = 5;
getUserBytes() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional string user = 5;
getUserBytes() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional string user = 5;
getUserBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional string user = 6;
getUserBytes() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional string user = 6;
getUserBytes() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional string user = 6;
getUserChannel(AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Gets the ChannelType properly from the USER_NETWORK_NETTY_CHANNEL property key.
getUserFromAuthorization(String, AlluxioConfiguration) - Static method in class alluxio.proxy.s3.S3RestUtils
Gets the user from the authorization header string for AWS Signature Version 4.
getUserFromAuthorization(String, AlluxioConfiguration) - Static method in class alluxio.s3.NettyRestUtils
Gets the user from the authorization header string for AWS Signature Version 4.
getUserInfoForChannel(UUID) - Method in interface alluxio.security.authentication.AuthenticationServer
 
getUserInfoForChannel(UUID) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
getUserName(long) - Static method in class alluxio.fuse.AlluxioFuseUtils
Gets the user name from the user id.
getUserState() - Method in class alluxio.client.block.stream.BlockWorkerClientPool
 
getUserState() - Method in class alluxio.ClientContext
 
getUserState() - Method in class alluxio.common.RpcPortHealthCheckClient
 
getUserState() - Method in class alluxio.master.MasterContext
 
getUuid() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional string uuid = 3;
getUuid() - Method in class alluxio.grpc.CompleteFilePRequest
optional string uuid = 3;
getUuid() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
optional string uuid = 3;
getUuid() - Method in class alluxio.grpc.CreateFilePResponse.Builder
uuid of its open file handle
getUuid() - Method in class alluxio.grpc.CreateFilePResponse
uuid of its open file handle
getUuid() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
uuid of its open file handle
getUUID() - Method in class alluxio.worker.dora.OpenFileHandle
Get UUID.
getUuidBytes() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional string uuid = 3;
getUuidBytes() - Method in class alluxio.grpc.CompleteFilePRequest
optional string uuid = 3;
getUuidBytes() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
optional string uuid = 3;
getUuidBytes() - Method in class alluxio.grpc.CreateFilePResponse.Builder
uuid of its open file handle
getUuidBytes() - Method in class alluxio.grpc.CreateFilePResponse
uuid of its open file handle
getUuidBytes() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
uuid of its open file handle
getValidationWithResult() - Method in class alluxio.cli.hms.CreateHmsClientValidationTask
 
getValue() - Method in enum alluxio.client.file.cache.CacheManager.State
 
getValue() - Method in enum alluxio.client.ReadType
 
getValue() - Method in enum alluxio.client.WriteType
 
getValue() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
getValue() - Method in class alluxio.grpc.ConfigProperty
optional string value = 3;
getValue() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string value = 3;
getValue() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
getValue() - Method in class alluxio.grpc.LocationBlockIdListEntry
optional .alluxio.grpc.block.BlockIdList value = 2;
getValue() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
optional .alluxio.grpc.block.BlockIdList value = 2;
getValue() - Method in class alluxio.grpc.Metric.Builder
optional double value = 4;
getValue() - Method in class alluxio.grpc.Metric
optional double value = 4;
getValue() - Method in interface alluxio.grpc.MetricOrBuilder
optional double value = 4;
getValue() - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
getValue(String) - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
getValue() - Method in class alluxio.metrics.Metric
 
getValue(String) - Method in interface alluxio.metrics.MultiValueMetricsAggregator
Gets the metric value of the given fully qualified metric name.
getValue(Map<MetricsFilter, Set<Metric>>) - Method in interface alluxio.metrics.SingleValueAggregator
Gets the aggregated value from the filtered metrics.
getValue() - Method in class alluxio.metrics.TimeSeries.DataPoint
 
getValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
getValue() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string value = 2;
getValue() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string value = 2;
getValue() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string value = 3;
getValue() - Method in class alluxio.proto.journal.Job.FileFilter
required string value = 3;
getValue() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
required string value = 3;
getValue() - Method in enum alluxio.underfs.UnderFileSystem.SpaceType
 
getValue() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
 
getValue() - Method in enum alluxio.wire.CommandType
 
getValue() - Method in enum alluxio.wire.LoadMetadataType
 
getValue() - Method in class alluxio.wire.Property
 
getValueBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
getValueBytes() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
getValueBytes() - Method in class alluxio.grpc.ConfigProperty
optional string value = 3;
getValueBytes() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string value = 3;
getValueBytes() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
getValueBytes() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string value = 2;
getValueBytes() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string value = 2;
getValueBytes() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string value = 3;
getValueBytes() - Method in class alluxio.proto.journal.Job.FileFilter
required string value = 3;
getValueBytes() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
required string value = 3;
getValueCase() - Method in class alluxio.grpc.table.Value.Builder
 
getValueCase() - Method in class alluxio.grpc.table.Value
 
getValueCase() - Method in interface alluxio.grpc.table.ValueOrBuilder
 
getValueCase() - Method in class alluxio.grpc.WriteRequest.Builder
 
getValueCase() - Method in class alluxio.grpc.WriteRequest
 
getValueCase() - Method in interface alluxio.grpc.WriteRequestOrBuilder
 
getValueDescriptor() - Method in enum alluxio.grpc.BackupState
 
getValueDescriptor() - Method in enum alluxio.grpc.Bits
 
getValueDescriptor() - Method in enum alluxio.grpc.BlockMasterInfoField
 
getValueDescriptor() - Method in enum alluxio.grpc.ChannelAuthenticationScheme
 
getValueDescriptor() - Method in enum alluxio.grpc.CommandType
 
getValueDescriptor() - Method in enum alluxio.grpc.ConfigStatus
 
getValueDescriptor() - Method in enum alluxio.grpc.ErrorType
 
getValueDescriptor() - Method in enum alluxio.grpc.JobMasterMetaCommand
 
getValueDescriptor() - Method in enum alluxio.grpc.JobProgressReportFormat
 
getValueDescriptor() - Method in enum alluxio.grpc.JobSource
 
getValueDescriptor() - Method in enum alluxio.grpc.JobType
 
getValueDescriptor() - Method in enum alluxio.grpc.JournalDomain
 
getValueDescriptor() - Method in enum alluxio.grpc.LoadDescendantPType
 
getValueDescriptor() - Method in enum alluxio.grpc.LoadMetadataPType
 
getValueDescriptor() - Method in enum alluxio.grpc.MasterInfoField
 
getValueDescriptor() - Method in enum alluxio.grpc.MetaCommand
 
getValueDescriptor() - Method in enum alluxio.grpc.MetricType
 
getValueDescriptor() - Method in enum alluxio.grpc.NodeState
 
getValueDescriptor() - Method in enum alluxio.grpc.OperationType
 
getValueDescriptor() - Method in enum alluxio.grpc.PAclAction
 
getValueDescriptor() - Method in enum alluxio.grpc.PAclEntryType
 
getValueDescriptor() - Method in enum alluxio.grpc.QuorumServerState
 
getValueDescriptor() - Method in enum alluxio.grpc.ReadPType
 
getValueDescriptor() - Method in enum alluxio.grpc.RequestType
 
getValueDescriptor() - Method in enum alluxio.grpc.SaslMessageType
 
getValueDescriptor() - Method in enum alluxio.grpc.Scope
 
getValueDescriptor() - Method in enum alluxio.grpc.ServiceType
 
getValueDescriptor() - Method in enum alluxio.grpc.SetAclAction
 
getValueDescriptor() - Method in enum alluxio.grpc.Status
 
getValueDescriptor() - Method in enum alluxio.grpc.SyncPointStatus
 
getValueDescriptor() - Method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
 
getValueDescriptor() - Method in enum alluxio.grpc.table.PrincipalType
 
getValueDescriptor() - Method in enum alluxio.grpc.table.TableInfo.TableType
 
getValueDescriptor() - Method in enum alluxio.grpc.TaskStatus
 
getValueDescriptor() - Method in enum alluxio.grpc.TtlAction
 
getValueDescriptor() - Method in enum alluxio.grpc.UfsPMode
 
getValueDescriptor() - Method in enum alluxio.grpc.WorkerInfoField
 
getValueDescriptor() - Method in enum alluxio.grpc.WorkerRange
 
getValueDescriptor() - Method in enum alluxio.grpc.WritePType
 
getValueDescriptor() - Method in enum alluxio.grpc.XAttrPropagationStrategy
 
getValueDescriptor() - Method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
getValueDescriptor() - Method in enum alluxio.proto.dataserver.Protocol.RequestType
 
getValueDescriptor() - Method in enum alluxio.proto.journal.File.PSetAclAction
 
getValueDescriptor() - Method in enum alluxio.proto.journal.File.PTtlAction
 
getValueDescriptor() - Method in enum alluxio.proto.journal.File.UfsMode
 
getValueDescriptor() - Method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
 
getValueDescriptor() - Method in enum alluxio.proto.journal.Job.PJobState
 
getValueDescriptor() - Method in enum alluxio.proto.shared.Acl.AclAction
 
getValueDescriptor() - Method in enum alluxio.proto.shared.Acl.AclEntryType
 
getValueDescriptor() - Method in enum alluxio.proto.status.Status.PStatus
 
getValueFromStaticMapping(String, String) - Static method in class alluxio.util.CommonUtils
Gets the value with a given key from a static key/value mapping in string format.
getValueOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
getValueOrBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry
optional .alluxio.grpc.block.BlockIdList value = 2;
getValueOrBuilder() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
optional .alluxio.grpc.block.BlockIdList value = 2;
getValues() - Method in class alluxio.grpc.InconsistentProperty.Builder
Deprecated.
getValues() - Method in class alluxio.grpc.InconsistentProperty
Deprecated.
getValues() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
Deprecated.
getValues(int) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
getValues(int) - Method in class alluxio.grpc.InconsistentPropertyValues
repeated string values = 1;
getValues(int) - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
repeated string values = 1;
getValues(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
getValues(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
list of string values for each partition column
getValues(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
list of string values for each partition column
getValues() - Method in class alluxio.wire.InconsistentProperty
 
getValuesBytes(int) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
getValuesBytes(int) - Method in class alluxio.grpc.InconsistentPropertyValues
repeated string values = 1;
getValuesBytes(int) - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
repeated string values = 1;
getValuesBytes(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
getValuesBytes(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
list of string values for each partition column
getValuesBytes(int) - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
list of string values for each partition column
getValuesCount() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
getValuesCount() - Method in class alluxio.grpc.InconsistentProperty
 
getValuesCount() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesCount() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
getValuesCount() - Method in class alluxio.grpc.InconsistentPropertyValues
repeated string values = 1;
getValuesCount() - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
repeated string values = 1;
getValuesCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
getValuesCount() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
list of string values for each partition column
getValuesCount() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
list of string values for each partition column
getValueSetCase() - Method in class alluxio.grpc.table.Domain.Builder
 
getValueSetCase() - Method in class alluxio.grpc.table.Domain
 
getValueSetCase() - Method in interface alluxio.grpc.table.DomainOrBuilder
 
getValuesList() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
getValuesList() - Method in class alluxio.grpc.InconsistentPropertyValues
repeated string values = 1;
getValuesList() - Method in interface alluxio.grpc.InconsistentPropertyValuesOrBuilder
repeated string values = 1;
getValuesList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
getValuesList() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
list of string values for each partition column
getValuesList() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
list of string values for each partition column
getValuesMap() - Method in class alluxio.grpc.InconsistentProperty.Builder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesMap() - Method in class alluxio.grpc.InconsistentProperty
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesMap() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesOrDefault(String, InconsistentPropertyValues) - Method in class alluxio.grpc.InconsistentProperty.Builder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesOrDefault(String, InconsistentPropertyValues) - Method in class alluxio.grpc.InconsistentProperty
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesOrDefault(String, InconsistentPropertyValues) - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesOrThrow(String) - Method in class alluxio.grpc.InconsistentProperty.Builder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesOrThrow(String) - Method in class alluxio.grpc.InconsistentProperty
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getValuesOrThrow(String) - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
getVerbose() - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional bool verbose = 2;
getVerbose() - Method in class alluxio.grpc.JobProgressPOptions
optional bool verbose = 2;
getVerbose() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
optional bool verbose = 2;
getVerify() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool verify = 2;
getVerify() - Method in class alluxio.grpc.CopyJobPOptions
optional bool verify = 2;
getVerify() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool verify = 2;
getVerify() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool verify = 2;
getVerify() - Method in class alluxio.grpc.LoadJobPOptions
optional bool verify = 2;
getVerify() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool verify = 2;
getVerify() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool verify = 2;
getVerify() - Method in class alluxio.grpc.MoveJobPOptions
optional bool verify = 2;
getVerify() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool verify = 2;
getVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool verify = 5;
getVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required bool verify = 5;
getVerify() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required bool verify = 5;
getVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool verify = 4;
getVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required bool verify = 4;
getVerify() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required bool verify = 4;
getVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool verify = 5;
getVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required bool verify = 5;
getVerify() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required bool verify = 5;
getVersion() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get Alluxio version.
getVersion() - Method in class alluxio.grpc.BuildVersion.Builder
the project version
getVersion() - Method in class alluxio.grpc.BuildVersion
the project version
getVersion() - Method in interface alluxio.grpc.BuildVersionOrBuilder
the project version
getVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
optional int64 version = 1;
getVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse
optional int64 version = 1;
getVersion() - Method in interface alluxio.grpc.GetServiceVersionPResponseOrBuilder
optional int64 version = 1;
getVersion() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
getVersion() - Method in class alluxio.grpc.JobMasterStatus
optional .alluxio.grpc.BuildVersion version = 4;
getVersion() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional .alluxio.grpc.BuildVersion version = 4;
getVersion() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
getVersion() - Method in class alluxio.grpc.JobWorkerHealth
optional .alluxio.grpc.BuildVersion version = 8;
getVersion() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional .alluxio.grpc.BuildVersion version = 8;
getVersion() - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
getVersion() - Method in class alluxio.grpc.MasterInfo
optional string version = 7;
getVersion() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string version = 7;
getVersion() - Method in class alluxio.grpc.MasterVersion.Builder
optional string version = 2;
getVersion() - Method in class alluxio.grpc.MasterVersion
optional string version = 2;
getVersion() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional string version = 2;
getVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
getVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional .alluxio.grpc.BuildVersion version = 3;
getVersion() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional .alluxio.grpc.BuildVersion version = 3;
getVersion() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
getVersion() - Method in class alluxio.grpc.ProxyStatus
optional .alluxio.grpc.BuildVersion version = 5;
getVersion() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional .alluxio.grpc.BuildVersion version = 5;
getVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
getVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions
optional .alluxio.grpc.BuildVersion version = 4;
getVersion() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
optional .alluxio.grpc.BuildVersion version = 4;
getVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
getVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.BuildVersion version = 3;
getVersion() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.BuildVersion version = 3;
getVersion() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string version = 4;
getVersion() - Method in class alluxio.grpc.RegisterMasterPOptions
optional string version = 4;
getVersion() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional string version = 4;
getVersion() - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version = 4;
getVersion() - Method in class alluxio.grpc.table.Partition
optional int64 version = 4;
getVersion() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional int64 version = 4;
getVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version = 10;
getVersion() - Method in class alluxio.grpc.table.TableInfo
optional int64 version = 10;
getVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional int64 version = 10;
getVersion() - Method in class alluxio.grpc.WorkerIdentity.Builder
version of the definition of the opaque identifier
getVersion() - Method in class alluxio.grpc.WorkerIdentity
version of the definition of the opaque identifier
getVersion() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
version of the definition of the opaque identifier
getVersion() - Method in class alluxio.job.MasterWorkerInfo
 
getVersion() - Method in class alluxio.job.wire.JobWorkerHealth
 
getVersion() - Method in class alluxio.master.backcompat.Journal
 
getVersion() - Method in class alluxio.master.meta.JobMasterInfo
 
getVersion() - Method in class alluxio.master.meta.MasterInfo
 
getVersion() - Method in class alluxio.master.meta.ProxyInfo
 
getVersion() - Method in class alluxio.s3.signature.SignatureInfo
 
getVersion() - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
 
getVersion() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
 
getVersion() - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
 
getVersion() - Method in interface alluxio.underfs.UnderFileSystemFactory
Get the version supported by this factory.
getVersion() - Method in class alluxio.util.webui.NodeInfo
Gets worker version.
getVersion() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getVersion() - Method in class alluxio.wire.AlluxioMasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioProxyInfo
 
getVersion() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getVersion() - Method in class alluxio.wire.MasterInfo
 
getVersion() - Method in class alluxio.wire.MasterWebUIOverview
Gets version.
getVersion() - Method in class alluxio.wire.WorkerIdentity.ParserV0
 
getVersion() - Method in class alluxio.wire.WorkerIdentity.ParserV1
 
getVersion() - Method in class alluxio.wire.WorkerInfo
 
getVersion() - Method in class alluxio.wire.WorkerWebUIOverview
Gets version.
getVersion() - Method in class alluxio.worker.http.HttpRequestUri
Get the version of the request URI.
getVersionBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
getVersionBuilder() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
getVersionBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
getVersionBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
getVersionBuilder() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
getVersionBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
getVersionBytes() - Method in class alluxio.grpc.BuildVersion.Builder
the project version
getVersionBytes() - Method in class alluxio.grpc.BuildVersion
the project version
getVersionBytes() - Method in interface alluxio.grpc.BuildVersionOrBuilder
the project version
getVersionBytes() - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
getVersionBytes() - Method in class alluxio.grpc.MasterInfo
optional string version = 7;
getVersionBytes() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string version = 7;
getVersionBytes() - Method in class alluxio.grpc.MasterVersion.Builder
optional string version = 2;
getVersionBytes() - Method in class alluxio.grpc.MasterVersion
optional string version = 2;
getVersionBytes() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional string version = 2;
getVersionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string version = 4;
getVersionBytes() - Method in class alluxio.grpc.RegisterMasterPOptions
optional string version = 4;
getVersionBytes() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional string version = 4;
getVersionCreationTime() - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version_creation_time = 5;
getVersionCreationTime() - Method in class alluxio.grpc.table.Partition
optional int64 version_creation_time = 5;
getVersionCreationTime() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional int64 version_creation_time = 5;
getVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version_creation_time = 11;
getVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo
optional int64 version_creation_time = 11;
getVersionCreationTime() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional int64 version_creation_time = 11;
getVersionId() - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
 
getVersionId() - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
getVersionOrBuilder() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
getVersionOrBuilder() - Method in class alluxio.grpc.JobMasterStatus
optional .alluxio.grpc.BuildVersion version = 4;
getVersionOrBuilder() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional .alluxio.grpc.BuildVersion version = 4;
getVersionOrBuilder() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
getVersionOrBuilder() - Method in class alluxio.grpc.JobWorkerHealth
optional .alluxio.grpc.BuildVersion version = 8;
getVersionOrBuilder() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional .alluxio.grpc.BuildVersion version = 8;
getVersionOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
getVersionOrBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional .alluxio.grpc.BuildVersion version = 3;
getVersionOrBuilder() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional .alluxio.grpc.BuildVersion version = 3;
getVersionOrBuilder() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
getVersionOrBuilder() - Method in class alluxio.grpc.ProxyStatus
optional .alluxio.grpc.BuildVersion version = 5;
getVersionOrBuilder() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional .alluxio.grpc.BuildVersion version = 5;
getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobMasterPOptions
optional .alluxio.grpc.BuildVersion version = 4;
getVersionOrBuilder() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
optional .alluxio.grpc.BuildVersion version = 4;
getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
getVersionOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.BuildVersion version = 3;
getVersionOrBuilder() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.BuildVersion version = 3;
getVersionSpecificRepresentation0(WorkerIdentity) - Method in class alluxio.wire.WorkerIdentity.ParserV0
 
getVersionSpecificRepresentation0(WorkerIdentity) - Method in class alluxio.wire.WorkerIdentity.ParserV1
 
getViewingOffset() - Method in class alluxio.wire.MasterWebUIBrowse
Gets viewing offset.
getViewingOffset() - Method in class alluxio.wire.MasterWebUILogs
Gets viewing offset.
getViewingOffset() - Method in class alluxio.wire.WorkerWebUILogs
Gets viewing offset.
getVolatileBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of a block given its block id or empty if block does not exist.
getWaitTimeNanos(long) - Method in interface alluxio.util.RateLimiter
Checks how long is needed to wait for this permit to be ready.
getWaitTimeNanos(long) - Method in class alluxio.util.SimpleRateLimiter
 
getWarns() - Method in class alluxio.grpc.ConfigCheckReport.Builder
Deprecated.
getWarns() - Method in class alluxio.grpc.ConfigCheckReport
Deprecated.
getWarns() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Deprecated.
getWarnsCount() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
getWarnsCount() - Method in class alluxio.grpc.ConfigCheckReport
 
getWarnsCount() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getWarnsMap() - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
getWarnsMap() - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
getWarnsMap() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getWarnsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
getWarnsOrDefault(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
getWarnsOrDefault(String, InconsistentProperties) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getWarnsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
getWarnsOrThrow(String) - Method in class alluxio.grpc.ConfigCheckReport
Scope name as key
getWarnsOrThrow(String) - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
Scope name as key
getWarnTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
 
getWebAddress() - Method in class alluxio.master.MasterProcess
 
getWebAddress() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
getWebAddress() - Method in interface alluxio.worker.JobWorkerProcess
 
getWebBindAddress() - Method in class alluxio.master.MasterProcess
 
getWebBindHost() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getWebBindHost() - Method in interface alluxio.worker.WorkerProcess
 
getWebFileInfoEnabled() - Method in class alluxio.wire.MasterWebUIInit
Gets web file info enabled.
getWebFileInfoEnabled() - Method in class alluxio.wire.WorkerWebUIInit
Gets web file info enabled.
getWebLocalPort() - Method in class alluxio.proxy.AlluxioProxyProcess
 
getWebLocalPort() - Method in interface alluxio.proxy.ProxyProcess
 
getWebLocalPort() - Method in class alluxio.worker.AlluxioWorkerProcess
 
getWebLocalPort() - Method in interface alluxio.worker.WorkerProcess
 
getWebPort() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get web port.
getWebPort() - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 webPort = 8;
getWebPort() - Method in class alluxio.grpc.MasterInfo
optional int32 webPort = 8;
getWebPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int32 webPort = 8;
getWebPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 webPort = 4;
getWebPort() - Method in class alluxio.grpc.WorkerNetAddress
optional int32 webPort = 4;
getWebPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional int32 webPort = 4;
getWebPort() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getWebPort() - Method in interface alluxio.master.meta.MetaMaster
 
getWebPort() - Method in class alluxio.multi.process.MasterNetAddress
 
getWebPort() - Method in class alluxio.util.webui.NodeInfo
Gets web port.
getWebPort() - Method in class alluxio.wire.WorkerNetAddress
 
getWebUIBrowse(String, String, String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI browse page data.
getWebUIConfiguration() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI Configuration page data.
getWebUIData(String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI data page data.
getWebUIInit() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI initialization data.
getWebUILogs(String, String, String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI logs page data.
getWebUIMasters() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI Master page data.
getWebUIMetrics() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI metrics page data.
getWebUIMountTable() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI mount table page data.
getWebUIOverview() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI overview page data.
getWebUIWorkers() - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
Gets Web UI workers page data.
getWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
optional bool white_list = 2;
getWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet
optional bool white_list = 2;
getWhiteList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
optional bool white_list = 2;
getWhiteList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getWhiteList() - Method in interface alluxio.master.file.FileSystemMaster
 
getWhitelist() - Method in class alluxio.wire.MasterWebUIConfiguration
Gets whitelist.
getWhitelist() - Method in class alluxio.wire.WorkerWebUIConfiguration
Gets whitelist.
getWhiteList() - Method in interface alluxio.worker.block.BlockWorker
 
getWid() - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
getWidthNano() - Method in class alluxio.job.util.TimeSeries
 
getWorker(long) - Method in interface alluxio.master.block.BlockMaster
Returns the internal MasterWorkerInfo object to the caller.
getWorker(long) - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorker() - Method in class alluxio.master.LocalAlluxioJobCluster
 
getWorker(Class<T>) - Method in class alluxio.worker.AlluxioWorkerProcess
 
getWorker() - Method in class alluxio.worker.netty.FileReadHandler
Gets worker.
getWorker() - Method in class alluxio.worker.netty.FileWriteHandler
 
getWorker(Class<T>) - Method in interface alluxio.worker.WorkerProcess
 
getWorkerAddress() - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
getWorkerAddress() - Method in class alluxio.grpc.BlockLocation
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
getWorkerAddress() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
getWorkerAddress() - Method in class alluxio.job.MasterWorkerInfo
 
getWorkerAddress() - Method in class alluxio.master.block.meta.MasterWorkerInfo
StaticWorkerMeta is thread safe so the value can be read without locking.
getWorkerAddress() - Method in class alluxio.master.LocalAlluxioCluster
 
getWorkerAddress() - Method in class alluxio.util.webui.UIWorkerInfo
Gets worker address.
getWorkerAddress() - Method in class alluxio.wire.BlockLocation
 
getWorkerAddress() - Method in interface alluxio.worker.block.BlockWorker
 
getWorkerAddressBuilder() - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
getWorkerAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddresses(int) - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddresses(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddresses() - Method in interface alluxio.master.block.BlockMaster
 
getWorkerAddresses() - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerAddresses() - Method in class alluxio.master.meta.DefaultMetaMaster
 
getWorkerAddresses() - Method in interface alluxio.master.meta.MetaMaster
 
getWorkerAddressesBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesCount() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesCount() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesList() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesOrBuilder(int) - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesOrBuilder(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesOrBuilderList() - Method in class alluxio.grpc.MasterInfo
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressesOrBuilderList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
getWorkerAddressOrBuilder() - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
getWorkerAddressOrBuilder() - Method in class alluxio.grpc.BlockLocation
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
getWorkerAddressOrBuilder() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
getWorkerAssignPolicy() - Method in class alluxio.master.job.AbstractJob
Gets the worker assign policy.
getWorkerCapacityFreePercentage() - Method in class alluxio.wire.WorkerWebUIMetrics
Gets worker capacity free percentage.
getWorkerCapacityUsedPercentage() - Method in class alluxio.wire.WorkerWebUIMetrics
Gets worker capacity used percentage.
getWorkerChannel(AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Gets the worker channel properly from the WORKER_NETWORK_NETTY_CHANNEL property key.
getWorkerClient(WorkerNetAddress) - Method in class alluxio.master.scheduler.DefaultWorkerProvider
 
getWorkerClient(WorkerNetAddress) - Method in class alluxio.master.scheduler.MembershipManagerWorkerProvider
 
getWorkerClient(WorkerNetAddress) - Method in interface alluxio.master.scheduler.WorkerProvider
Gets a worker client.
getWorkerCount() - Method in interface alluxio.master.block.BlockMaster
 
getWorkerCount() - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerDataDirectory(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
 
getWorkerHealth() - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Get worker health info.
getWorkerHealths(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealths(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealths(int) - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsBuilderList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsCount() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsCount() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsCount() - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsList() - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsOrBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsOrBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsOrBuilder(int) - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsOrBuilderList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsOrBuilderList() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHealthsOrBuilderList() - Method in interface alluxio.grpc.GetAllWorkerHealthPResponseOrBuilder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
getWorkerHost() - Method in class alluxio.grpc.JobInfo.Builder
optional string workerHost = 12;
getWorkerHost() - Method in class alluxio.grpc.JobInfo
optional string workerHost = 12;
getWorkerHost() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string workerHost = 12;
getWorkerHost() - Method in class alluxio.job.plan.replicate.MoveConfig
 
getWorkerHost() - Method in class alluxio.job.wire.TaskInfo
 
getWorkerHostBytes() - Method in class alluxio.grpc.JobInfo.Builder
optional string workerHost = 12;
getWorkerHostBytes() - Method in class alluxio.grpc.JobInfo
optional string workerHost = 12;
getWorkerHostBytes() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string workerHost = 12;
getWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
required string workerHostname = 1;
getWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions
required string workerHostname = 1;
getWorkerHostname() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
required string workerHostname = 1;
getWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
required string workerHostname = 1;
getWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
required string workerHostname = 1;
getWorkerHostname() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
required string workerHostname = 1;
getWorkerHostnameBytes() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
required string workerHostname = 1;
getWorkerHostnameBytes() - Method in class alluxio.grpc.DecommissionWorkerPOptions
required string workerHostname = 1;
getWorkerHostnameBytes() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
required string workerHostname = 1;
getWorkerHostnameBytes() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
required string workerHostname = 1;
getWorkerHostnameBytes() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
required string workerHostname = 1;
getWorkerHostnameBytes() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
required string workerHostname = 1;
getWorkerHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets list of workers in conf directory.
getWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the id of the worker
getWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest
the id of the worker
getWorkerId() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the id of the worker
getWorkerId() - Method in class alluxio.grpc.BlockLocation.Builder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.BlockLocation
optional int64 workerId = 1;
getWorkerId() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional int64 workerId = 1;
getWorkerId(GetWorkerIdPRequest, StreamObserver<GetWorkerIdPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
Returns a worker id for the given network address.
getWorkerId(GetWorkerIdPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
Returns a worker id for the given network address.
getWorkerId(GetWorkerIdPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
Returns a worker id for the given network address.
getWorkerId(GetWorkerIdPRequest, StreamObserver<GetWorkerIdPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Returns a worker id for the given network address.
getWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the worker
getWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest
the id of the worker
getWorkerId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the id of the worker
getWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the id of the worker
getWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
the id of the worker
getWorkerId() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
the id of the worker
getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest
optional int64 workerId = 1;
getWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional int64 workerId = 1;
getWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse
optional int64 workerId = 1;
getWorkerId() - Method in interface alluxio.grpc.GetWorkerIdPResponseOrBuilder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.JobWorkerHealth
optional int64 workerId = 1;
getWorkerId() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
optional int64 workerId = 1;
getWorkerId() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
optional int64 workerId = 1;
getWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the id of the worker
getWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest
the id of the worker
getWorkerId() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the id of the worker
getWorkerId() - Method in class alluxio.job.wire.JobWorkerHealth
 
getWorkerId(WorkerNetAddress) - Method in interface alluxio.master.block.BlockMaster
Returns a worker id for the given worker, creating one if the worker is new.
getWorkerId(GetWorkerIdPRequest, StreamObserver<GetWorkerIdPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
getWorkerId(WorkerNetAddress) - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerId() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
getWorkerId() - Method in class alluxio.master.block.WorkerRegisterContext
Getter for worker ID.
getWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional int64 worker_id = 1;
getWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation
optional int64 worker_id = 1;
getWorkerId() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional int64 worker_id = 1;
getWorkerId() - Method in class alluxio.util.webui.NodeInfo
Gets worker id.
getWorkerId() - Method in class alluxio.wire.BlockLocation
 
getWorkerId() - Method in interface alluxio.worker.DataWorker
 
getWorkerId() - Method in class alluxio.worker.dora.PagedDoraWorker
 
getWorkerId() - Static method in class alluxio.worker.JobWorkerIdRegistry
 
getWorkerIdAddressMap() - Method in class alluxio.client.block.AllMastersWorkerInfo
 
getWorkerIdInfoMap() - Method in class alluxio.client.block.AllMastersWorkerInfo
 
GetWorkerIdPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerIdPOptions
GetWorkerIdPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerIdPOptions
GetWorkerIdPOptionsOrBuilder - Interface in alluxio.grpc
 
GetWorkerIdPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerIdPRequest
GetWorkerIdPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerIdPRequest
GetWorkerIdPRequestOrBuilder - Interface in alluxio.grpc
 
GetWorkerIdPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerIdPResponse
GetWorkerIdPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerIdPResponse
GetWorkerIdPResponseOrBuilder - Interface in alluxio.grpc
 
getWorkerInfo() - Method in class alluxio.master.block.WorkerRegisterContext
 
getWorkerInfo() - Method in class alluxio.wire.WorkerWebUIOverview
Gets worker info.
getWorkerInfoHub() - Method in class alluxio.master.scheduler.Scheduler
Get the workerinfo hub.
getWorkerInfoList() - Method in interface alluxio.client.block.BlockMasterClient
Gets the worker information of live workers(support older version Alluxio server).
getWorkerInfoList() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getWorkerInfoList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns a list of workers information.
getWorkerInfoList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns a list of workers information.
getWorkerInfoList(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns a list of workers information.
getWorkerInfoList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns a list of workers information.
getWorkerInfoList() - Method in interface alluxio.master.block.BlockMaster
 
getWorkerInfoList(GetWorkerInfoListPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getWorkerInfoList() - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerInfoList() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
getWorkerInfoList() - Method in interface alluxio.master.file.FileSystemMaster
 
getWorkerInfoList() - Method in class alluxio.master.file.meta.FileSystemMasterView
 
getWorkerInfoList() - Method in class alluxio.master.job.JobMaster
 
GetWorkerInfoListPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerInfoListPOptions
GetWorkerInfoListPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerInfoListPOptions
GetWorkerInfoListPOptionsOrBuilder - Interface in alluxio.grpc
 
GetWorkerInfoListPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerInfoListPResponse
GetWorkerInfoListPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerInfoListPResponse
GetWorkerInfoListPResponseOrBuilder - Interface in alluxio.grpc
 
getWorkerInfos(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfos(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfos(int) - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfos() - Method in class alluxio.master.scheduler.DefaultWorkerProvider
 
getWorkerInfos() - Method in class alluxio.master.scheduler.MembershipManagerWorkerProvider
 
getWorkerInfos() - Method in interface alluxio.master.scheduler.WorkerProvider
Gets a list of worker information.
getWorkerInfosBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosBuilderList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosCount() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosCount() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosCount() - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosList() - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosOrBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosOrBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosOrBuilder(int) - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosOrBuilderList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosOrBuilderList() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerInfosOrBuilderList() - Method in interface alluxio.grpc.GetWorkerInfoListPResponseOrBuilder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
getWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
getWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions
If specified, the data will be written to the certain worker
getWorkerLocation() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
If specified, the data will be written to the certain worker
getWorkerLocationBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
getWorkerLocationOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
getWorkerLocationOrBuilder() - Method in class alluxio.grpc.CreateFilePOptions
If specified, the data will be written to the certain worker
getWorkerLocationOrBuilder() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
If specified, the data will be written to the certain worker
getWorkerLostStorage() - Method in interface alluxio.client.block.BlockMasterClient
 
getWorkerLostStorage() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getWorkerLostStorage(GetWorkerLostStoragePOptions, StreamObserver<GetWorkerLostStoragePResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns a list of worker lost storage information
getWorkerLostStorage(GetWorkerLostStoragePOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns a list of worker lost storage information
getWorkerLostStorage(GetWorkerLostStoragePOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns a list of worker lost storage information
getWorkerLostStorage(GetWorkerLostStoragePOptions, StreamObserver<GetWorkerLostStoragePResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns a list of worker lost storage information
getWorkerLostStorage() - Method in interface alluxio.master.block.BlockMaster
 
getWorkerLostStorage(GetWorkerLostStoragePOptions, StreamObserver<GetWorkerLostStoragePResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getWorkerLostStorage() - Method in class alluxio.master.block.DefaultBlockMaster
 
getWorkerLostStorageInfo(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfo(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfo(int) - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoBuilderList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoCount() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoCount() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoCount() - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoList() - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoOrBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoOrBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoOrBuilder(int) - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoOrBuilderList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoOrBuilderList() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
getWorkerLostStorageInfoOrBuilderList() - Method in interface alluxio.grpc.GetWorkerLostStoragePResponseOrBuilder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
GetWorkerLostStoragePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePOptions
GetWorkerLostStoragePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePOptions
GetWorkerLostStoragePOptionsOrBuilder - Interface in alluxio.grpc
 
GetWorkerLostStoragePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePResponse
GetWorkerLostStoragePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerLostStoragePResponse
GetWorkerLostStoragePResponseOrBuilder - Interface in alluxio.grpc
 
getWorkerNetAddress(String) - Method in class alluxio.client.file.dora.DoraCacheClient
Get the worker net address of the specific file path.
getWorkerNetAddress(AlluxioURI) - Method in class alluxio.client.file.DoraCacheFileSystem
Get the worker address which the specified file locates at.
getWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
getWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest
the worker network address
getWorkerNetAddress() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
the worker network address
getWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
getWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
the worker network address
getWorkerNetAddress() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
the worker network address
getWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
getWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
getWorkerNetAddress() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
getWorkerNetAddress() - Method in class alluxio.membership.WorkerServiceEntity
Get WorkerNetAddress field.
getWorkerNetAddressBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
getWorkerNetAddressBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
getWorkerNetAddressBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest
the worker network address
getWorkerNetAddressOrBuilder() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
the worker network address
getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
the worker network address
getWorkerNetAddressOrBuilder() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
the worker network address
getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
getWorkerNetAddressOrBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
getWorkerNetAddressOrBuilder() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
getWorkerPort() - Method in class alluxio.wire.MasterWebUIInit
Gets worker port.
getWorkerProcess() - Method in class alluxio.master.LocalAlluxioCluster
 
getWorkerProcess(int) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
getWorkerProcess(int) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
getWorkerRange() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
getWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
getWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
getWorkerRange() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
getWorkerReport(GetWorkerReportOptions) - Method in interface alluxio.client.block.BlockMasterClient
Gets the worker information of selected workers and selected fields for report CLI.
getWorkerReport(GetWorkerReportOptions) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
getWorkerReport(GetWorkerReportPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
Returns a list of workers information for report CLI.
getWorkerReport(GetWorkerReportPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
Returns a list of workers information for report CLI.
getWorkerReport(GetWorkerReportPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
Returns a list of workers information for report CLI.
getWorkerReport(GetWorkerReportPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
Returns a list of workers information for report CLI.
getWorkerReport(GetWorkerReportOptions) - Method in interface alluxio.master.block.BlockMaster
Gets the worker information list for report CLI.
getWorkerReport(GetWorkerReportPOptions, StreamObserver<GetWorkerInfoListPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
getWorkerReport(GetWorkerReportOptions) - Method in class alluxio.master.block.DefaultBlockMaster
 
GetWorkerReportOptions - Class in alluxio.client.block.options
Worker information options.
GetWorkerReportOptions(GetWorkerReportPOptions) - Constructor for class alluxio.client.block.options.GetWorkerReportOptions
Creates a new instance of GetWorkerReportOptions from a proto representation.
GetWorkerReportOptions.WorkerInfoField - Enum in alluxio.client.block.options
Enum representing the fields of the worker information.
GetWorkerReportOptions.WorkerRange - Enum in alluxio.client.block.options
Enum representing the range of workers that we want to show capacity information for.
GetWorkerReportPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerReportPOptions
GetWorkerReportPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.GetWorkerReportPOptions
GetWorkerReportPOptionsOrBuilder - Interface in alluxio.grpc
 
getWorkerReportsFromAllMasters(AlluxioConfiguration, BlockMasterClient, GetWorkerReportOptions) - Static method in class alluxio.client.block.util.WorkerInfoUtil
Get worker reports from all masters, including standby masters.
getWorkers() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
 
getWorkersThatHaveData() - Method in class alluxio.cli.fs.command.FileLocation
Get the workers where data locate.
getWorkerToTaskQ() - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoHub
 
getWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional int64 workerWebPort = 2;
getWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions
optional int64 workerWebPort = 2;
getWorkerWebPort() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
optional int64 workerWebPort = 2;
getWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
optional int64 workerWebPort = 2;
getWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
optional int64 workerWebPort = 2;
getWorkerWebPort() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
optional int64 workerWebPort = 2;
getWorkerWithMostBlocks(List<BlockWorkerInfo>, List<FileBlockInfo>) - Static method in class alluxio.job.util.JobUtils
Returns whichever specified worker stores the most blocks from the block info list.
getWorkflowConfigClass() - Method in class alluxio.job.workflow.composite.CompositeExecutionFactory
 
getWorkflowConfigClass() - Method in interface alluxio.job.workflow.WorkflowExecutionFactory
 
getWorkingDirectory(CommandLine) - Method in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
Gets the directory that this command should output to.
getWorkingDirectory() - Method in class alluxio.hadoop.AbstractFileSystem
 
getWorkingDirectory() - Method in class alluxio.hadoop.LocalCacheFileSystem
 
getWriteBlockMethod() - Static method in class alluxio.grpc.BlockWorkerGrpc
 
getWriteLock() - Method in class alluxio.master.file.meta.MountTable
Returns the underlying write lock of the MountTable.
getWriteOffset() - Method in class alluxio.fuse.OpenFileEntry
 
getWriteOptions() - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptions() - Method in class alluxio.grpc.CopyRequest
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptions() - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptions() - Method in class alluxio.grpc.MoveRequest
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsOrBuilder() - Method in class alluxio.grpc.CopyRequest
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsOrBuilder() - Method in interface alluxio.grpc.CopyRequestOrBuilder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsOrBuilder() - Method in class alluxio.grpc.MoveRequest
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriteOptionsOrBuilder() - Method in interface alluxio.grpc.MoveRequestOrBuilder
required .alluxio.grpc.block.WriteOptions write_options = 3;
getWriter() - Method in interface alluxio.master.journalv0.MutableJournal
 
getWriter() - Method in class alluxio.master.journalv0.ufs.UfsMutableJournal
 
getWriteSpeedStat() - Method in class alluxio.stress.worker.IOTaskSummary
 
getWriteTier() - Method in class alluxio.client.file.options.OutStreamOptions
 
getWriteTier() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 writeTier = 7;
getWriteTier() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 writeTier = 7;
getWriteTier() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 writeTier = 7;
getWriteType() - Method in class alluxio.client.file.options.OutStreamOptions
 
getWriteType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.CopyJobPOptions
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
getWriteType() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
getWriteType() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
getWriteType() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.MoveJobPOptions
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
getWriteType() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.WriteOptions.Builder
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.grpc.WriteOptions
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
getWriteType() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
getWriteType() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
getWriteType() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
getWriteType() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getXAttr() - Method in class alluxio.client.file.URIStatus
 
getXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
Deprecated.
getXattr() - Method in class alluxio.grpc.CreateDirectoryPOptions
Deprecated.
getXattr() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
Deprecated.
getXattr() - Method in class alluxio.grpc.CreateFilePOptions.Builder
Deprecated.
getXattr() - Method in class alluxio.grpc.CreateFilePOptions
Deprecated.
getXattr() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
Deprecated.
getXattr() - Method in class alluxio.grpc.FileInfo.Builder
Deprecated.
getXattr() - Method in class alluxio.grpc.FileInfo
Deprecated.
getXattr() - Method in interface alluxio.grpc.FileInfoOrBuilder
Deprecated.
getXattr() - Method in class alluxio.grpc.SetAttributePOptions.Builder
Deprecated.
getXattr() - Method in class alluxio.grpc.SetAttributePOptions
Deprecated.
getXattr() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
Deprecated.
getXattr() - Method in class alluxio.grpc.UfsStatus.Builder
Deprecated.
getXattr() - Method in class alluxio.grpc.UfsStatus
Deprecated.
getXattr() - Method in interface alluxio.grpc.UfsStatusOrBuilder
Deprecated.
getXAttr() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getXAttr() - Method in class alluxio.master.file.meta.Inode
 
getXAttr() - Method in interface alluxio.master.file.meta.InodeView
 
getXAttr() - Method in class alluxio.master.file.meta.MutableInode
 
getXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
Deprecated.
getXAttr() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
Deprecated.
getXAttr() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
Deprecated.
getXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
Deprecated.
getXAttr() - Method in class alluxio.proto.journal.File.InodeFileEntry
Deprecated.
getXAttr() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
Deprecated.
getXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
Deprecated.
getXAttr() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
Deprecated.
getXAttr() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
Deprecated.
getXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Deprecated.
getXAttr() - Method in class alluxio.proto.meta.InodeMeta.Inode
Deprecated.
getXAttr() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Deprecated.
getXAttr() - Method in class alluxio.underfs.UfsStatus
Returns the extended attributes from the Ufs, if any.
getXAttr() - Method in class alluxio.wire.FileInfo
 
getxattrCallback(String, String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
getXattrCount() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
getXattrCount() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
getXattrCount() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
map<string, bytes> xattr = 6;
getXattrCount() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
getXattrCount() - Method in class alluxio.grpc.CreateFilePOptions
 
getXattrCount() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrCount() - Method in class alluxio.grpc.FileInfo.Builder
 
getXattrCount() - Method in class alluxio.grpc.FileInfo
 
getXattrCount() - Method in interface alluxio.grpc.FileInfoOrBuilder
map<string, bytes> xattr = 32;
getXattrCount() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
getXattrCount() - Method in class alluxio.grpc.SetAttributePOptions
 
getXattrCount() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrCount() - Method in class alluxio.grpc.UfsStatus.Builder
 
getXattrCount() - Method in class alluxio.grpc.UfsStatus
 
getXattrCount() - Method in interface alluxio.grpc.UfsStatusOrBuilder
map<string, bytes> xattr = 7;
getXAttrCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
getXAttrCount() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
getXAttrCount() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
map<string, bytes> xAttr = 19;
getXAttrCount() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
getXAttrCount() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
getXAttrCount() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
map<string, bytes> xAttr = 28;
getXAttrCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
getXAttrCount() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
getXAttrCount() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
map<string, bytes> xAttr = 17;
getXAttrCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
getXAttrCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
getXAttrCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Extended attributes, general purpose.
getXattrMap() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
map<string, bytes> xattr = 6;
getXattrMap() - Method in class alluxio.grpc.CreateDirectoryPOptions
map<string, bytes> xattr = 6;
getXattrMap() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
map<string, bytes> xattr = 6;
getXattrMap() - Method in class alluxio.grpc.CreateFilePOptions.Builder
map<string, bytes> xattr = 11;
getXattrMap() - Method in class alluxio.grpc.CreateFilePOptions
map<string, bytes> xattr = 11;
getXattrMap() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrMap() - Method in class alluxio.grpc.FileInfo.Builder
map<string, bytes> xattr = 32;
getXattrMap() - Method in class alluxio.grpc.FileInfo
map<string, bytes> xattr = 32;
getXattrMap() - Method in interface alluxio.grpc.FileInfoOrBuilder
map<string, bytes> xattr = 32;
getXattrMap() - Method in class alluxio.grpc.SetAttributePOptions.Builder
map<string, bytes> xattr = 11;
getXattrMap() - Method in class alluxio.grpc.SetAttributePOptions
map<string, bytes> xattr = 11;
getXattrMap() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrMap() - Method in class alluxio.grpc.UfsStatus.Builder
map<string, bytes> xattr = 7;
getXattrMap() - Method in class alluxio.grpc.UfsStatus
map<string, bytes> xattr = 7;
getXattrMap() - Method in interface alluxio.grpc.UfsStatusOrBuilder
map<string, bytes> xattr = 7;
getXAttrMap() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
map<string, bytes> xAttr = 19;
getXAttrMap() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
map<string, bytes> xAttr = 19;
getXAttrMap() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
map<string, bytes> xAttr = 19;
getXAttrMap() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
map<string, bytes> xAttr = 28;
getXAttrMap() - Method in class alluxio.proto.journal.File.InodeFileEntry
map<string, bytes> xAttr = 28;
getXAttrMap() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
map<string, bytes> xAttr = 28;
getXAttrMap() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
map<string, bytes> xAttr = 17;
getXAttrMap() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
map<string, bytes> xAttr = 17;
getXAttrMap() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
map<string, bytes> xAttr = 17;
getXAttrMap() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Extended attributes, general purpose.
getXAttrMap() - Method in class alluxio.proto.meta.InodeMeta.Inode
Extended attributes, general purpose.
getXAttrMap() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Extended attributes, general purpose.
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
map<string, bytes> xattr = 6;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateDirectoryPOptions
map<string, bytes> xattr = 6;
getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
map<string, bytes> xattr = 6;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateFilePOptions.Builder
map<string, bytes> xattr = 11;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.CreateFilePOptions
map<string, bytes> xattr = 11;
getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.FileInfo.Builder
map<string, bytes> xattr = 32;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.FileInfo
map<string, bytes> xattr = 32;
getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.FileInfoOrBuilder
map<string, bytes> xattr = 32;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
map<string, bytes> xattr = 11;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.SetAttributePOptions
map<string, bytes> xattr = 11;
getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
map<string, bytes> xattr = 7;
getXattrOrDefault(String, ByteString) - Method in class alluxio.grpc.UfsStatus
map<string, bytes> xattr = 7;
getXattrOrDefault(String, ByteString) - Method in interface alluxio.grpc.UfsStatusOrBuilder
map<string, bytes> xattr = 7;
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
map<string, bytes> xAttr = 19;
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
map<string, bytes> xAttr = 19;
getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
map<string, bytes> xAttr = 19;
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
map<string, bytes> xAttr = 28;
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry
map<string, bytes> xAttr = 28;
getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
map<string, bytes> xAttr = 28;
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
map<string, bytes> xAttr = 17;
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
map<string, bytes> xAttr = 17;
getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
map<string, bytes> xAttr = 17;
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Extended attributes, general purpose.
getXAttrOrDefault(String, ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode
Extended attributes, general purpose.
getXAttrOrDefault(String, ByteString) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Extended attributes, general purpose.
getXattrOrThrow(String) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
map<string, bytes> xattr = 6;
getXattrOrThrow(String) - Method in class alluxio.grpc.CreateDirectoryPOptions
map<string, bytes> xattr = 6;
getXattrOrThrow(String) - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
map<string, bytes> xattr = 6;
getXattrOrThrow(String) - Method in class alluxio.grpc.CreateFilePOptions.Builder
map<string, bytes> xattr = 11;
getXattrOrThrow(String) - Method in class alluxio.grpc.CreateFilePOptions
map<string, bytes> xattr = 11;
getXattrOrThrow(String) - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrOrThrow(String) - Method in class alluxio.grpc.FileInfo.Builder
map<string, bytes> xattr = 32;
getXattrOrThrow(String) - Method in class alluxio.grpc.FileInfo
map<string, bytes> xattr = 32;
getXattrOrThrow(String) - Method in interface alluxio.grpc.FileInfoOrBuilder
map<string, bytes> xattr = 32;
getXattrOrThrow(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
map<string, bytes> xattr = 11;
getXattrOrThrow(String) - Method in class alluxio.grpc.SetAttributePOptions
map<string, bytes> xattr = 11;
getXattrOrThrow(String) - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
map<string, bytes> xattr = 11;
getXattrOrThrow(String) - Method in class alluxio.grpc.UfsStatus.Builder
map<string, bytes> xattr = 7;
getXattrOrThrow(String) - Method in class alluxio.grpc.UfsStatus
map<string, bytes> xattr = 7;
getXattrOrThrow(String) - Method in interface alluxio.grpc.UfsStatusOrBuilder
map<string, bytes> xattr = 7;
getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
map<string, bytes> xAttr = 19;
getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
map<string, bytes> xAttr = 19;
getXAttrOrThrow(String) - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
map<string, bytes> xAttr = 19;
getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
map<string, bytes> xAttr = 28;
getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.InodeFileEntry
map<string, bytes> xAttr = 28;
getXAttrOrThrow(String) - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
map<string, bytes> xAttr = 28;
getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
map<string, bytes> xAttr = 17;
getXAttrOrThrow(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
map<string, bytes> xAttr = 17;
getXAttrOrThrow(String) - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
map<string, bytes> xAttr = 17;
getXAttrOrThrow(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Extended attributes, general purpose.
getXAttrOrThrow(String) - Method in class alluxio.proto.meta.InodeMeta.Inode
Extended attributes, general purpose.
getXAttrOrThrow(String) - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Extended attributes, general purpose.
getXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
getXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
getXattrPropStrat() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
getXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
getXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
getXattrPropStrat() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
getXAttrPropStrat() - Method in class alluxio.master.file.contexts.CreatePathContext
 
getXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
getXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
getXattrUpdateStrategy() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
getXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
getXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
getXAttrUpdateStrategy() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
getZkAddress() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
getZone() - Method in class alluxio.clock.ElapsedTimeClock
 
getZone() - Method in class alluxio.clock.SystemClock
 
getZookeeperAddress() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get zookeeper address.
getZookeeperAddress() - Method in class alluxio.uri.ZookeeperAuthority
 
getZookeeperAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
getZookeeperAddresses(int) - Method in class alluxio.grpc.MasterInfo
Empty means zookeeper is not enabled
getZookeeperAddresses(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
Empty means zookeeper is not enabled
getZookeeperAddressesBytes(int) - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
getZookeeperAddressesBytes(int) - Method in class alluxio.grpc.MasterInfo
Empty means zookeeper is not enabled
getZookeeperAddressesBytes(int) - Method in interface alluxio.grpc.MasterInfoOrBuilder
Empty means zookeeper is not enabled
getZookeeperAddressesCount() - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
getZookeeperAddressesCount() - Method in class alluxio.grpc.MasterInfo
Empty means zookeeper is not enabled
getZookeeperAddressesCount() - Method in interface alluxio.grpc.MasterInfoOrBuilder
Empty means zookeeper is not enabled
getZookeeperAddressesList() - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
getZookeeperAddressesList() - Method in class alluxio.grpc.MasterInfo
Empty means zookeeper is not enabled
getZookeeperAddressesList() - Method in interface alluxio.grpc.MasterInfoOrBuilder
Empty means zookeeper is not enabled
GLOBAL - Static variable in class alluxio.client.quota.CacheScope
 
global() - Static method in class alluxio.conf.Configuration
 
global() - Static method in class alluxio.security.user.ServerUserState
 
GLOBAL_RATE_LIMITER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
 
GraceMode - Enum in alluxio.master
Defines the grace mode of exclusive locking of the state-lock.
Graph - Class in alluxio.stress.graph
A representation of a graph.
Graph() - Constructor for class alluxio.stress.graph.Graph
 
graphGenerator() - Method in class alluxio.stress.client.ClientIOSummary
 
GraphGenerator() - Constructor for class alluxio.stress.client.ClientIOSummary.GraphGenerator
 
graphGenerator() - Method in class alluxio.stress.client.ClientIOTaskResult
 
GraphGenerator() - Constructor for class alluxio.stress.client.ClientIOTaskResult.GraphGenerator
 
GraphGenerator - Class in alluxio.stress
This generates graphs from a list of summaries.
GraphGenerator() - Constructor for class alluxio.stress.GraphGenerator
 
graphGenerator() - Method in interface alluxio.stress.Summary
 
graphGenerator() - Method in class alluxio.stress.worker.IOTaskSummary
 
GraphGenerator() - Constructor for class alluxio.stress.worker.IOTaskSummary.GraphGenerator
 
graphGenerator() - Method in class alluxio.stress.worker.WorkerBenchSummary
 
GraphGenerator() - Constructor for class alluxio.stress.worker.WorkerBenchSummary.GraphGenerator
 
GraphiteSink - Class in alluxio.metrics.sink
A sink which publishes metric values to a Graphite server.
GraphiteSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.GraphiteSink
Creates a new GraphiteSink with a Properties and MetricRegistry.
GROUP_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
GROUP_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
GROUPACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
GROUPBITS_FIELD_NUMBER - Static variable in class alluxio.grpc.PMode
 
GroupMappingService - Interface in alluxio.security.group
Interface for Alluxio user-to-groups mapping.
GroupMappingService.Factory - Class in alluxio.security.group
Factory for creating a new instance.
GRPC_REFLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
GRPC_REFLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
GrpcBlockingStream<ReqT,ResT> - Class in alluxio.client.block.stream
A helper class for accessing gRPC bi-directional stream synchronously.
GrpcBlockingStream(Function<StreamObserver<ResT>, StreamObserver<ReqT>>, int, String) - Constructor for class alluxio.client.block.stream.GrpcBlockingStream
 
GrpcCallTracker - Class in alluxio.master.file.contexts
CallTracker implementation for gRPC calls.
GrpcCallTracker(StreamObserver<?>) - Constructor for class alluxio.master.file.contexts.GrpcCallTracker
Creates a call tracker for gRPC.
GrpcChannel - Class in alluxio.grpc
Used to gather gRPC level resources and indexes together.
GrpcChannel(GrpcChannelKey, ManagedChannel) - Constructor for class alluxio.grpc.GrpcChannel
Creates a new connection object.
GrpcChannelBuilder - Class in alluxio.grpc
A gRPC channel builder that authenticates with GrpcServer at the target during channel building.
GrpcChannelBuilder(GrpcServerAddress, AlluxioConfiguration, AuthType, boolean) - Constructor for class alluxio.grpc.GrpcChannelBuilder
 
GrpcChannelKey - Class in alluxio.grpc
Used to define a key for GrpcChannelPool.
GrpcChannelKey(GrpcNetworkGroup, GrpcServerAddress, int) - Constructor for class alluxio.grpc.GrpcChannelKey
Constructor.
GrpcChannelPool - Class in alluxio.grpc
Used to provide gRPC level connection management and pooling facilities.
GrpcDataMessageBlockingStream<ReqT,ResT> - Class in alluxio.client.block.stream
A helper class for accessing gRPC bi-directional stream synchronously.
GrpcDataMessageBlockingStream(Function<StreamObserver<ResT>, StreamObserver<ReqT>>, int, String, DataMessageMarshaller<ReqT>, DataMessageMarshaller<ResT>) - Constructor for class alluxio.client.block.stream.GrpcDataMessageBlockingStream
 
GrpcDataReader - Class in alluxio.client.block.stream
A gRPC data reader that streams a region from gRPC data server.
GrpcDataReader.Factory - Class in alluxio.client.block.stream
Factory class to create GrpcDataReaders.
GrpcDataServer - Class in alluxio.worker.grpc
Runs a gRPC data server that responds to block requests.
GrpcDataServer(String, SocketAddress, BlockWorkerGrpc.BlockWorkerImplBase) - Constructor for class alluxio.worker.grpc.GrpcDataServer
Creates a new instance of GrpcDataServer.
GrpcDataWriter - Class in alluxio.client.block.stream
A gRPC data writer that streams a full block or a UFS file to a gRPC data server.
GrpcExceptionUtils - Class in alluxio.grpc
Utility methods for conversion between alluxio and grpc status exceptions.
GrpcExceptionUtils() - Constructor for class alluxio.grpc.GrpcExceptionUtils
 
GrpcExecutors - Class in alluxio.worker.grpc
Executors for gRPC block server.
GrpcMessagingClient - Class in alluxio.master.transport
Client implementation based on Alluxio gRPC messaging.
GrpcMessagingClient(AlluxioConfiguration, UserState, ExecutorService) - Constructor for class alluxio.master.transport.GrpcMessagingClient
Creates messaging client that can be used to connect to remote messaging servers.
GrpcMessagingClientConnection - Class in alluxio.master.transport
GrpcMessagingConnection implementation for clients.
GrpcMessagingClientConnection(GrpcMessagingContext, ExecutorService, GrpcChannel, long) - Constructor for class alluxio.master.transport.GrpcMessagingClientConnection
Creates a messaging connection for client.
GrpcMessagingConnection - Class in alluxio.master.transport
Abstract GrpcMessagingConnection implementation based on Alluxio gRPC messaging.
GrpcMessagingConnection(GrpcMessagingConnection.ConnectionOwner, String, GrpcMessagingContext, ExecutorService, long) - Constructor for class alluxio.master.transport.GrpcMessagingConnection
Creates a connection object.
GrpcMessagingConnection.ConnectionOwner - Enum in alluxio.master.transport
Defines the owner of connection.
GrpcMessagingConnection.ContextualFuture<T> - Class in alluxio.master.transport
A future with catalyst thread context.
GrpcMessagingConnection.HandlerHolder - Class in alluxio.master.transport
Holds message handler and catalyst thread context.
GrpcMessagingContext - Class in alluxio.master.transport
The context for Grpc messaging single thread.
GrpcMessagingContext(String, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
Constructs a new GrpcMessagingContext.
GrpcMessagingContext(GrpcMessagingThreadFactory, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
Constructs a new single thread GrpcMessagingContext.
GrpcMessagingContext(ScheduledExecutorService, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
Constructs a new single thread GrpcMessagingContext.
GrpcMessagingContext(Thread, ScheduledExecutorService, Serializer) - Constructor for class alluxio.master.transport.GrpcMessagingContext
Constructs a new GrpcMessagingContext.
GrpcMessagingProxy - Class in alluxio.master.transport
Used to provide external proxy configuration to messaging servers/clients.
GrpcMessagingProxy() - Constructor for class alluxio.master.transport.GrpcMessagingProxy
Creates new proxy configuration.
GrpcMessagingServer - Class in alluxio.master.transport
Server implementation based on Alluxio gRPC messaging.
GrpcMessagingServer(AlluxioConfiguration, UserState, ExecutorService, GrpcMessagingProxy) - Constructor for class alluxio.master.transport.GrpcMessagingServer
Creates a transport server that can be used to accept connections from remote clients.
GrpcMessagingServerConnection - Class in alluxio.master.transport
GrpcMessagingConnection implementation for server.
GrpcMessagingServerConnection(String, GrpcMessagingContext, ExecutorService, long) - Constructor for class alluxio.master.transport.GrpcMessagingServerConnection
Creates a messaging connection for server.
GrpcMessagingServiceClientHandler - Class in alluxio.master.transport
gRPC service handler for message exchange between messaging clients and servers that are created by GrpcMessagingTransport.
GrpcMessagingServiceClientHandler(InetSocketAddress, Consumer<GrpcMessagingConnection>, GrpcMessagingContext, ExecutorService, long) - Constructor for class alluxio.master.transport.GrpcMessagingServiceClientHandler
 
GrpcMessagingThread - Class in alluxio.master.transport
A thread used for Grpc messaging and stores a GrpcMessagingContext for current thread.
GrpcMessagingThread(Runnable, String) - Constructor for class alluxio.master.transport.GrpcMessagingThread
Constructs a new GrpcMessagingThread.
GrpcMessagingThreadFactory - Class in alluxio.master.transport
The factory to create new GrpcMessagingThread with name.
GrpcMessagingThreadFactory(String) - Constructor for class alluxio.master.transport.GrpcMessagingThreadFactory
Constructs a new GrpcMessagingThreadFactory which names thread.
GrpcMessagingTransport - Class in alluxio.master.transport
Transport implementation based on Alluxio gRPC messaging.
GrpcMessagingTransport(AlluxioConfiguration, UserState, String) - Constructor for class alluxio.master.transport.GrpcMessagingTransport
Creates GrpcMessagingTransport based on Alluxio gRPC messaging.
GrpcMessagingTransport(AlluxioConfiguration, AlluxioConfiguration, UserState, UserState, String) - Constructor for class alluxio.master.transport.GrpcMessagingTransport
Creates GrpcMessagingTransport based on Alluxio gRPC messaging.
GrpcNetworkGroup - Enum in alluxio.grpc
Used to define connection level multiplexing groups.
GrpcSerializationUtils - Class in alluxio.grpc
Utilities for gRPC message serialization.
GrpcSerializationUtils() - Constructor for class alluxio.grpc.GrpcSerializationUtils
 
GrpcServer - Class in alluxio.grpc
An authenticated gRPC server.
GrpcServer(Server, AuthenticationServer, Closer, long) - Constructor for class alluxio.grpc.GrpcServer
Create a new instance of GrpcServer.
GrpcServerAddress - Class in alluxio.grpc
Defines an gRPC server endpoint.
GrpcServerBuilder - Class in alluxio.grpc
Provides authenticated gRPC server creation.
GrpcServerModule - Class in alluxio.worker.modules
Grpc worker module.
GrpcServerModule() - Constructor for class alluxio.worker.modules.GrpcServerModule
 
GrpcService - Class in alluxio.grpc
Utility class for wrapping gRPC service definition.
GrpcService(BindableService) - Constructor for class alluxio.grpc.GrpcService
Creates a new GrpcService.
GrpcService(ServerServiceDefinition) - Constructor for class alluxio.grpc.GrpcService
Creates a new GrpcService.
GrpcUtils - Class in alluxio.grpc
Utility methods for conversion between wire types and grpc types.
GzipMarshaller - Class in alluxio.util.compression
Applies a simple Gzip compression to the NoCompressionMarshaller.
GzipMarshaller() - Constructor for class alluxio.util.compression.GzipMarshaller
 

H

HADOOP_AUTH_METHOD - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
HADOOP_CONF_DIR_ENV_VAR - Static variable in class alluxio.cli.hdfs.HdfsConfParityValidationTask
Name of the environment variable to store the path to Hadoop config directory.
HADOOP_CONF_DIR_OPTION - Static variable in class alluxio.cli.hdfs.HdfsConfParityValidationTask
 
HADOOP_KERBEROS_KEYTAB_LOGIN_AUTORENEWAL - Static variable in class alluxio.conf.PropertyKey
 
HADOOP_KERBEROS_KEYTAB_LOGIN_AUTORENEWAL - Static variable in class alluxio.conf.PropertyKey.Name
 
HADOOP_KRB5_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
HADOOP_KRB5_CONF_KEY_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
HADOOP_PREFIX - Static variable in class alluxio.cli.hdfs.HdfsVersionValidationTask
 
HADOOP_SECURITY_AUTHENTICATION - Static variable in class alluxio.conf.PropertyKey
 
HADOOP_SECURITY_AUTHENTICATION - Static variable in class alluxio.conf.PropertyKey.Name
 
HADOOP_VERSION - Static variable in class alluxio.ProjectConstants
 
HadoopBenchThreadState() - Constructor for class alluxio.fsmaster.FileSystemBench.HadoopBenchThreadState
 
HadoopConfigurationFileParser - Class in alluxio.cli.hdfs
Parser for configuration files.
HadoopConfigurationFileParser() - Constructor for class alluxio.cli.hdfs.HadoopConfigurationFileParser
Constructs a HadoopConfigurationFileParser object.
HadoopConfigurationUtils - Class in alluxio.hadoop
Utility class for merging AlluxioConfiguration with Hadoop's Configuration class.
HadoopFileOpener - Interface in alluxio.hadoop
Interface to wrap open method of file system.
hadoopGetFileStatusBench(Blackhole, FileSystemBench.HadoopBenchThreadState) - Method in class alluxio.fsmaster.FileSystemBench
 
HadoopUtils - Class in alluxio.hadoop
Utility class for using Alluxio with Hadoop.
handle(BiFunction<? super T, Throwable, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
handle(BiFunction<? super T, Throwable, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes either normally or exceptionally, is executed with this stage's result and exception as arguments to the supplied function.
handle(Signal) - Method in class alluxio.fuse.FuseSignalHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler
Process s3 multipart upload request.
handle(Callback[]) - Method in class alluxio.security.authentication.plain.PlainSaslClientCallbackHandler
 
handle(Callback[]) - Method in class alluxio.security.authentication.plain.PlainSaslServerCallbackHandler
 
handle(Callback[]) - Method in class alluxio.security.login.AppLoginModule.AppCallbackHandler
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes either normally or exceptionally, is executed using this stage's default asynchronous execution facility, with this stage's result and exception as arguments to the supplied function.
handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes either normally or exceptionally, is executed using the supplied executor, with this stage's result and exception as arguments to the supplied function.
handleContent(HttpContent) - Method in class alluxio.worker.s3.S3NettyBaseTask
Run core S3 API logic with HttpContent in different S3 task.
handleJournalReplayFailure(Logger, Throwable, String, Object...) - Static method in class alluxio.master.journal.JournalUtils
Logs a fatal error and exits the system if required.
handleMessage(SaslMessage) - Method in class alluxio.security.authentication.AbstractSaslClientHandler
This is synchronized in order to protect AbstractSaslClientHandler.mSaslClient.
handleMessage(SaslMessage) - Method in class alluxio.security.authentication.AbstractSaslServerHandler
 
handleMessage(SaslMessage) - Method in interface alluxio.security.authentication.SaslClientHandler
Handles the given SaslMessage from the server.
handleMessage(SaslMessage) - Method in interface alluxio.security.authentication.SaslServerHandler
Handles given SaslMessage from the client.
handleNodeDelete(Address) - Method in class alluxio.master.meta.checkconf.ConfigurationStore
Updates configuration when a node delete.
handleNodeLost(Address) - Method in class alluxio.master.meta.checkconf.ConfigurationStore
Updates configuration when a live node becomes lost.
handler(Class<T>, Consumer<T>) - Method in class alluxio.master.transport.GrpcMessagingConnection
Registers a new message handler.
handler(Class<T>, Function<T, CompletableFuture<U>>) - Method in class alluxio.master.transport.GrpcMessagingConnection
Registers a new message handler.
handleResponseMessage(TransportMessage) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
handleTaskAsync() - Method in class alluxio.proxy.s3.S3BaseTask
Run S3 API logic in a customized async way, e.g.
handleTaskAsync() - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
 
handleTaskAsync() - Method in class alluxio.worker.s3.S3NettyBaseTask
Run S3 API logic in a customized async way, e.g.
HAS_DIRECT_CHILDREN_LOADED_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
hasAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
hasAccessAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
hasAccessAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
hasAccessMode() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.Bits accessMode = 3;
hasAccessMode() - Method in class alluxio.grpc.GetStatusPOptions
optional .alluxio.grpc.Bits accessMode = 3;
hasAccessMode() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional .alluxio.grpc.Bits accessMode = 3;
hasAcl() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
hasAcl() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.file.PAcl acl = 27;
hasAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.file.PAcl acl = 27;
hasAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
hasAcl() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional .alluxio.proto.shared.AccessControlList acl = 6;
hasAcl() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 6;
hasAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
hasAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList acl = 15;
hasAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 15;
hasAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
hasAcl() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional .alluxio.proto.shared.AccessControlList acl = 19;
hasAcl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 19;
hasAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
hasAcl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional .alluxio.proto.shared.AccessControlList acl = 14;
hasAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList acl = 14;
hasAction() - Method in class alluxio.grpc.SetAclPRequest.Builder
the set action to perform
hasAction() - Method in class alluxio.grpc.SetAclPRequest
the set action to perform
hasAction() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the set action to perform
hasAction() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional .alluxio.proto.journal.PSetAclAction action = 3;
hasAction() - Method in class alluxio.proto.journal.File.SetAclEntry
optional .alluxio.proto.journal.PSetAclAction action = 3;
hasAction() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional .alluxio.proto.journal.PSetAclAction action = 3;
hasActionId() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionId = 1;
hasActionId() - Method in class alluxio.grpc.ActionInfo
optional string actionId = 1;
hasActionId() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionId = 1;
hasActionId() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string actionId = 2;
hasActionId() - Method in class alluxio.grpc.GetActionInfoRequest
optional string actionId = 2;
hasActionId() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string actionId = 2;
hasActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
hasActions() - Method in class alluxio.proto.shared.Acl.NamedAclActions
optional .alluxio.proto.shared.AclActions actions = 2;
hasActions() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
optional .alluxio.proto.shared.AclActions actions = 2;
hasActionsCanceled() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsCanceled = 8;
hasActionsCanceled() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsCanceled = 8;
hasActionsCanceled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsCanceled = 8;
hasActionsFailed() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsFailed = 9;
hasActionsFailed() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsFailed = 9;
hasActionsFailed() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsFailed = 9;
hasActionsRunning() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsRunning = 6;
hasActionsRunning() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsRunning = 6;
hasActionsRunning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsRunning = 6;
hasActionsScheduled() - Method in class alluxio.grpc.PolicyStatus.Builder
metrics
hasActionsScheduled() - Method in class alluxio.grpc.PolicyStatus
metrics
hasActionsScheduled() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
metrics
hasActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsSucceeded = 7;
hasActionsSucceeded() - Method in class alluxio.grpc.PolicyStatus
optional int64 actionsSucceeded = 7;
hasActionsSucceeded() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 actionsSucceeded = 7;
hasActionStatus() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionStatus = 3;
hasActionStatus() - Method in class alluxio.grpc.ActionInfo
optional string actionStatus = 3;
hasActionStatus() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionStatus = 3;
hasActionType() - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionType = 2;
hasActionType() - Method in class alluxio.grpc.ActionInfo
optional string actionType = 2;
hasActionType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string actionType = 2;
hasActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
hasActiveSyncTxId() - Method in class alluxio.proto.journal.Journal.JournalEntry
action fields.
hasActiveSyncTxId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
action fields.
hasAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
hasAddMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
hasAddMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
hasAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
hasAddQuorumServerRequest() - Method in class alluxio.grpc.JournalQueryRequest
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
hasAddQuorumServerRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
hasAddress() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
hasAddress() - Method in class alluxio.grpc.ProxyStatus
optional .alluxio.grpc.NetAddress address = 1;
hasAddress() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional .alluxio.grpc.NetAddress address = 1;
hasAddress() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
hasAddress() - Method in class alluxio.grpc.WorkerInfo
optional .alluxio.grpc.WorkerNetAddress address = 2;
hasAddress() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional .alluxio.grpc.WorkerNetAddress address = 2;
hasAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
hasAddress() - Method in class alluxio.grpc.WorkerLostStorageInfo
optional .alluxio.grpc.WorkerNetAddress address = 1;
hasAddress() - Method in interface alluxio.grpc.WorkerLostStorageInfoOrBuilder
optional .alluxio.grpc.WorkerNetAddress address = 1;
hasAddresses() - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
hasAddresses() - Method in class alluxio.grpc.MasterVersion
optional .alluxio.grpc.NetAddress addresses = 1;
hasAddresses() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional .alluxio.grpc.NetAddress addresses = 1;
hasAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
hasAddSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
hasAddSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
hasAll() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
optional bool all = 1;
hasAll() - Method in class alluxio.grpc.table.AllOrNoneSet
optional bool all = 1;
hasAll() - Method in interface alluxio.grpc.table.AllOrNoneSetOrBuilder
optional bool all = 1;
hasAllOrNone() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
hasAllOrNone() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
hasAllOrNone() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
hasAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional bool allowed = 2;
hasAllowed() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional bool allowed = 2;
hasAllowed() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional bool allowed = 2;
hasAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
optional bool allowedOnStandbyMasters = 2;
hasAllowedOnStandbyMasters() - Method in class alluxio.grpc.GetServiceVersionPRequest
optional bool allowedOnStandbyMasters = 2;
hasAllowedOnStandbyMasters() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
optional bool allowedOnStandbyMasters = 2;
hasAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool allowExists = 2;
hasAllowExists() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional bool allowExists = 2;
hasAllowExists() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional bool allowExists = 2;
hasAllowLeader() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool allowLeader = 3;
hasAllowLeader() - Method in class alluxio.grpc.BackupPOptions
optional bool allowLeader = 3;
hasAllowLeader() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool allowLeader = 3;
hasAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool alluxioOnly = 2;
hasAlluxioOnly() - Method in class alluxio.grpc.DeletePOptions
optional bool alluxioOnly = 2;
hasAlluxioOnly() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool alluxioOnly = 2;
hasAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, this field is about whether to delete in the UFS.
hasAlluxioOnly() - Method in class alluxio.proto.journal.File.DeleteFileEntry
Deprecated, this field is about whether to delete in the UFS.
hasAlluxioOnly() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
Deprecated, this field is about whether to delete in the UFS.
hasAlluxioPath() - Method in class alluxio.grpc.File.Builder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.grpc.File
optional string alluxio_path = 1;
hasAlluxioPath() - Method in interface alluxio.grpc.FileOrBuilder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.grpc.MountPRequest.Builder
the path of alluxio mount point
hasAlluxioPath() - Method in class alluxio.grpc.MountPRequest
the path of alluxio mount point
hasAlluxioPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
the path of alluxio mount point
hasAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
optional string alluxioPath = 1;
hasAlluxioPath() - Method in class alluxio.grpc.ReverseResolvePResponse
optional string alluxioPath = 1;
hasAlluxioPath() - Method in interface alluxio.grpc.ReverseResolvePResponseOrBuilder
optional string alluxioPath = 1;
hasAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest.Builder
the path of the alluxio mount point
hasAlluxioPath() - Method in class alluxio.grpc.UnmountPRequest
the path of the alluxio mount point
hasAlluxioPath() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
the path of the alluxio mount point
hasAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
the path of alluxio mount point
hasAlluxioPath() - Method in class alluxio.grpc.UpdateMountPRequest
the path of alluxio mount point
hasAlluxioPath() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
the path of alluxio mount point
hasAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string alluxio_path = 1;
hasAlluxioPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
hasAlluxioPath() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
optional string alluxio_path = 1;
hasAlluxioPath() - Method in interface alluxio.proto.journal.File.DeleteMountPointEntryOrBuilder
optional string alluxio_path = 1;
hasAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional string alluxioVersion = 3;
hasAlluxioVersion() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
optional string alluxioVersion = 3;
hasAlluxioVersion() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
optional string alluxioVersion = 3;
hasAnnotation(PropertyKey) - Method in class alluxio.conf.DeprecatedKeyChecker
Returns whether or not the given property key is marked by this class' annotation.
hasAsync() - Method in class alluxio.grpc.CacheRequest.Builder
optional bool async = 6;
hasAsync() - Method in class alluxio.grpc.CacheRequest
optional bool async = 6;
hasAsync() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional bool async = 6;
hasAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
hasAsyncPersistOptions() - Method in class alluxio.grpc.CompleteFilePOptions
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
hasAsyncPersistOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
hasAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
hasAsyncPersistRequest() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
hasAsyncPersistRequest() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
hasAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
hasAuthenticationScheme() - Method in class alluxio.grpc.SaslMessage
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
hasAuthenticationScheme() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
hasAuthority() - Method in class alluxio.AlluxioURI
Tells if the AlluxioURI has authority or not.
hasAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional double avg_col_len = 2;
hasAvgColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional double avg_col_len = 2;
hasAvgColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional double avg_col_len = 2;
hasAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional double avg_col_len = 2;
hasAvgColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
optional double avg_col_len = 2;
hasAvgColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional double avg_col_len = 2;
hasBackupError() - Method in class alluxio.grpc.BackupPStatus.Builder
optional bytes backupError = 6;
hasBackupError() - Method in class alluxio.grpc.BackupPStatus
optional bytes backupError = 6;
hasBackupError() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional bytes backupError = 6;
hasBackupHost() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupHost = 3;
hasBackupHost() - Method in class alluxio.grpc.BackupPStatus
optional string backupHost = 3;
hasBackupHost() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupHost = 3;
hasBackupId() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupId = 1;
hasBackupId() - Method in class alluxio.grpc.BackupPStatus
optional string backupId = 1;
hasBackupId() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupId = 1;
hasBackupId() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
optional string backupId = 1;
hasBackupId() - Method in class alluxio.grpc.BackupStatusPRequest
optional string backupId = 1;
hasBackupId() - Method in interface alluxio.grpc.BackupStatusPRequestOrBuilder
optional string backupId = 1;
hasBackupState() - Method in class alluxio.grpc.BackupPStatus.Builder
optional .alluxio.grpc.meta.BackupState backupState = 2;
hasBackupState() - Method in class alluxio.grpc.BackupPStatus
optional .alluxio.grpc.meta.BackupState backupState = 2;
hasBackupState() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional .alluxio.grpc.meta.BackupState backupState = 2;
hasBackupUri() - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupUri = 4;
hasBackupUri() - Method in class alluxio.grpc.BackupPStatus
optional string backupUri = 4;
hasBackupUri() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional string backupUri = 4;
hasBandwidth() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional int64 bandwidth = 1;
hasBandwidth() - Method in class alluxio.grpc.CopyJobPOptions
optional int64 bandwidth = 1;
hasBandwidth() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional int64 bandwidth = 1;
hasBandwidth() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional int64 bandwidth = 1;
hasBandwidth() - Method in class alluxio.grpc.LoadJobPOptions
optional int64 bandwidth = 1;
hasBandwidth() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional int64 bandwidth = 1;
hasBandwidth() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional int64 bandwidth = 1;
hasBandwidth() - Method in class alluxio.grpc.MoveJobPOptions
optional int64 bandwidth = 1;
hasBandwidth() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional int64 bandwidth = 1;
hasBandwidth() - Method in class alluxio.grpc.UfsReadOptions.Builder
optional int64 bandwidth = 3;
hasBandwidth() - Method in class alluxio.grpc.UfsReadOptions
optional int64 bandwidth = 3;
hasBandwidth() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
optional int64 bandwidth = 3;
hasBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 bandwidth = 4;
hasBandwidth() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional int64 bandwidth = 4;
hasBandwidth() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional int64 bandwidth = 4;
hasBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 bandwidth = 3;
hasBandwidth() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional int64 bandwidth = 3;
hasBandwidth() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional int64 bandwidth = 3;
hasBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 bandwidth = 4;
hasBandwidth() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional int64 bandwidth = 4;
hasBandwidth() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional int64 bandwidth = 4;
hasBaseLayout() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
hasBaseLayout() - Method in class alluxio.grpc.table.Partition
optional .alluxio.grpc.table.Layout base_layout = 2;
hasBaseLayout() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional .alluxio.grpc.table.Layout base_layout = 2;
hasBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Batch size for partial listings.
hasBatchSize() - Method in class alluxio.grpc.ListStatusPartialPOptions
Batch size for partial listings.
hasBatchSize() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Batch size for partial listings.
hasBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
hasBinaryStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
hasBinaryStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
hasBits() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.Bits bits = 1;
hasBits() - Method in class alluxio.grpc.CheckAccessPOptions
optional .alluxio.grpc.Bits bits = 1;
hasBits() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
optional .alluxio.grpc.Bits bits = 1;
hasBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional string bit_vectors = 4;
hasBitVectors() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional string bit_vectors = 4;
hasBitVectors() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional string bit_vectors = 4;
hasBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional string bit_vectors = 4;
hasBitVectors() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional string bit_vectors = 4;
hasBitVectors() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional string bit_vectors = 4;
hasBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.DateColumnStatsData
optional string bit_vectors = 5;
hasBitVectors() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional string bit_vectors = 5;
hasBitVectors() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional string bit_vectors = 5;
hasBitVectors() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.LongColumnStatsData
optional string bit_vectors = 5;
hasBitVectors() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional string bit_vectors = 5;
hasBitVectors() - Method in class alluxio.grpc.table.StringColumnStatsData
optional string bit_vectors = 5;
hasBitVectors() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional string bit_vectors = 5;
hasBlock() - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
hasBlock() - Method in class alluxio.grpc.BlockStatus
required .alluxio.grpc.block.Block block = 1;
hasBlock() - Method in interface alluxio.grpc.BlockStatusOrBuilder
required .alluxio.grpc.block.Block block = 1;
hasBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
hasBlockContainerIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
hasBlockContainerIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
hasBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
hasBlockCount() - Method in class alluxio.grpc.GetRegisterLeasePRequest
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
hasBlockCount() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
hasBlockId() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.AsyncCacheRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.Block.Builder
required int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.Block
required int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 blockId = 1;
hasBlockId() - Method in class alluxio.grpc.BlockInfo
optional int64 blockId = 1;
hasBlockId() - Method in interface alluxio.grpc.BlockInfoOrBuilder
optional int64 blockId = 1;
hasBlockId() - Method in interface alluxio.grpc.BlockOrBuilder
required int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.CacheRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the block being committed
hasBlockId() - Method in class alluxio.grpc.CommitBlockPRequest
the id of the block being committed
hasBlockId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the id of the block being committed
hasBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
the id of the block
hasBlockId() - Method in class alluxio.grpc.GetBlockInfoPRequest
the id of the block
hasBlockId() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
the id of the block
hasBlockId() - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.MoveBlockRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.ReadRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.grpc.RemoveBlockRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.grpc.RemoveBlockRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCloseRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
hasBlockId() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
optional int64 block_id = 1;
hasBlockId() - Method in interface alluxio.proto.journal.Block.DeleteBlockEntryOrBuilder
optional int64 block_id = 1;
hasBlockInfo() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
hasBlockInfo() - Method in class alluxio.grpc.FileBlockInfo
optional .alluxio.grpc.BlockInfo blockInfo = 1;
hasBlockInfo() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
hasBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
hasBlockInfo() - Method in class alluxio.grpc.GetBlockInfoPResponse
optional .alluxio.grpc.BlockInfo blockInfo = 1;
hasBlockInfo() - Method in interface alluxio.grpc.GetBlockInfoPResponseOrBuilder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
hasBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
hasBlockInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
hasBlockInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
hasBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
hasBlockLocation() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional .alluxio.grpc.BlockLocation block_location = 3;
hasBlockLocation() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional .alluxio.grpc.BlockLocation block_location = 3;
hasBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
hasBlockMasterInfo() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
hasBlockMasterInfo() - Method in interface alluxio.grpc.GetBlockMasterInfoPResponseOrBuilder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
hasBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Checks if the storage has a given block.
hasBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Checks if a block is in this storage dir.
hasBlockSize() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 block_size = 3;
hasBlockSize() - Method in class alluxio.grpc.UfsFileStatus
optional int64 block_size = 3;
hasBlockSize() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
optional int64 block_size = 3;
hasBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The block size.
hasBlockSize() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
The block size.
hasBlockSize() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
The block size.
hasBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 blockSizeBytes = 1;
hasBlockSizeBytes() - Method in class alluxio.grpc.CreateFilePOptions
optional int64 blockSizeBytes = 1;
hasBlockSizeBytes() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int64 blockSizeBytes = 1;
hasBlockSizeBytes() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 blockSizeBytes = 6;
hasBlockSizeBytes() - Method in class alluxio.grpc.FileInfo
optional int64 blockSizeBytes = 6;
hasBlockSizeBytes() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 blockSizeBytes = 6;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 block_size_bytes = 8;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 block_size_bytes = 8;
hasBlockSizeBytes() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 block_size_bytes = 8;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 block_size_bytes = 2;
hasBlockSizeBytes() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 block_size_bytes = 2;
hasBlockSizeBytes() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 block_size_bytes = 2;
hasBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
file only
hasBlockSizeBytes() - Method in class alluxio.proto.meta.InodeMeta.Inode
file only
hasBlockSizeBytes() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
file only
hasBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
hasBooleanStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
hasBooleanStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
hasBooleanType() - Method in class alluxio.grpc.table.Value.Builder
bool boolean_type = 4;
hasBooleanType() - Method in class alluxio.grpc.table.Value
bool boolean_type = 4;
hasBooleanType() - Method in interface alluxio.grpc.table.ValueOrBuilder
bool boolean_type = 4;
hasBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
optional int64 bucket_count = 2;
hasBucketCount() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
optional int64 bucket_count = 2;
hasBucketCount() - Method in interface alluxio.grpc.table.layout.hive.HiveBucketPropertyOrBuilder
optional int64 bucket_count = 2;
hasBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
hasBucketProperty() - Method in class alluxio.grpc.table.layout.hive.Storage
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
hasBucketProperty() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
hasBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
hasBuildVersion() - Method in class alluxio.grpc.RegisterWorkerPOptions
the worker version to display in info pages (useful for rolling upgrades)
hasBuildVersion() - Method in interface alluxio.grpc.RegisterWorkerPOptionsOrBuilder
the worker version to display in info pages (useful for rolling upgrades)
hasBuildVersion() - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
hasBuildVersion() - Method in class alluxio.grpc.WorkerInfo
optional .alluxio.grpc.BuildVersion buildVersion = 10;
hasBuildVersion() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
hasBypassDelegation() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool bypassDelegation = 4;
hasBypassDelegation() - Method in class alluxio.grpc.BackupPOptions
optional bool bypassDelegation = 4;
hasBypassDelegation() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool bypassDelegation = 4;
hasBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
optional int64 bytes = 1;
hasBytes() - Method in class alluxio.grpc.GetCapacityBytesPResponse
optional int64 bytes = 1;
hasBytes() - Method in interface alluxio.grpc.GetCapacityBytesPResponseOrBuilder
optional int64 bytes = 1;
hasBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
optional int64 bytes = 1;
hasBytes() - Method in class alluxio.grpc.GetUsedBytesPResponse
optional int64 bytes = 1;
hasBytes() - Method in interface alluxio.grpc.GetUsedBytesPResponseOrBuilder
optional int64 bytes = 1;
hasBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int64 bytes_skipped = 4;
hasBytesSkipped() - Method in class alluxio.grpc.LoadFileResponse
optional int64 bytes_skipped = 4;
hasBytesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
optional int64 bytes_skipped = 4;
hasCacheable() - Method in class alluxio.grpc.FileInfo.Builder
optional bool cacheable = 11;
hasCacheable() - Method in class alluxio.grpc.FileInfo
optional bool cacheable = 11;
hasCacheable() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool cacheable = 11;
hasCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool cacheable = 11;
hasCacheable() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool cacheable = 11;
hasCacheable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool cacheable = 11;
hasCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool cacheable = 5;
hasCacheable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional bool cacheable = 5;
hasCacheable() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional bool cacheable = 5;
hasCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 cacheSize = 2;
hasCacheSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
optional int64 cacheSize = 2;
hasCacheSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
optional int64 cacheSize = 2;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
optional bool cancel = 2;
hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequestOrBuilder
optional bool cancel = 2;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, this request is to cancel the reading request for the id.
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
If set, this request is to cancel the reading request for the id.
hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
If set, this request is to cancel the reading request for the id.
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
hasCancel() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool cancel = 6;
hasCancel() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool cancel = 6;
hasCancelTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
hasCancelTaskCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
hasCancelTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
hasCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional bool canRegisterAgain = 3;
hasCanRegisterAgain() - Method in class alluxio.grpc.DecommissionWorkerPOptions
optional bool canRegisterAgain = 3;
hasCanRegisterAgain() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
optional bool canRegisterAgain = 3;
hasCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 capacityBytes = 1;
hasCapacityBytes() - Method in class alluxio.grpc.BlockMasterInfo
optional int64 capacityBytes = 1;
hasCapacityBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int64 capacityBytes = 1;
hasCapacityBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 capacityBytes = 5;
hasCapacityBytes() - Method in class alluxio.grpc.WorkerInfo
optional int64 capacityBytes = 5;
hasCapacityBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 capacityBytes = 5;
hasChannelRef() - Method in class alluxio.grpc.SaslMessage.Builder
optional string channelRef = 5;
hasChannelRef() - Method in class alluxio.grpc.SaslMessage
optional string channelRef = 5;
hasChannelRef() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional string channelRef = 5;
hasCheckContent() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool check_content = 6;
hasCheckContent() - Method in class alluxio.grpc.CopyJobPOptions
optional bool check_content = 6;
hasCheckContent() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool check_content = 6;
hasCheckContent() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool check_content = 6;
hasCheckContent() - Method in class alluxio.grpc.MoveJobPOptions
optional bool check_content = 6;
hasCheckContent() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool check_content = 6;
hasCheckContent() - Method in class alluxio.grpc.WriteOptions.Builder
optional bool check_content = 3;
hasCheckContent() - Method in class alluxio.grpc.WriteOptions
optional bool check_content = 3;
hasCheckContent() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
optional bool check_content = 3;
hasCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool check_content = 11;
hasCheckContent() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional bool check_content = 11;
hasCheckContent() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional bool check_content = 11;
hasCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool check_content = 11;
hasCheckContent() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional bool check_content = 11;
hasCheckContent() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional bool check_content = 11;
hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool checkS3BucketPath = 8;
hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional bool checkS3BucketPath = 8;
hasCheckS3BucketPath() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional bool checkS3BucketPath = 8;
hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool checkS3BucketPath = 14;
hasCheckS3BucketPath() - Method in class alluxio.grpc.CreateFilePOptions
optional bool checkS3BucketPath = 14;
hasCheckS3BucketPath() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool checkS3BucketPath = 14;
hasCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
optional bool checkUfs = 1;
hasCheckUfs() - Method in class alluxio.grpc.GetMountTablePRequest
optional bool checkUfs = 1;
hasCheckUfs() - Method in interface alluxio.grpc.GetMountTablePRequestOrBuilder
optional bool checkUfs = 1;
hasChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 child_count = 26;
hasChildCount() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 child_count = 26;
hasChildCount() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 child_count = 26;
hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
hasChildren(InodeDirectoryView, ReadOption) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
hasChildren(InodeDirectoryView) - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
hasChildren(InodeDirectoryView, ReadOption) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
hasChunk() - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
hasChunk() - Method in class alluxio.grpc.ReadResponse
optional .alluxio.grpc.block.Chunk chunk = 1;
hasChunk() - Method in interface alluxio.grpc.ReadResponseOrBuilder
optional .alluxio.grpc.block.Chunk chunk = 1;
hasChunk() - Method in class alluxio.grpc.SnapshotData.Builder
optional bytes chunk = 3;
hasChunk() - Method in class alluxio.grpc.SnapshotData
optional bytes chunk = 3;
hasChunk() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
optional bytes chunk = 3;
hasChunk() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
hasChunk() - Method in class alluxio.grpc.WriteRequest
.alluxio.grpc.block.Chunk chunk = 2;
hasChunk() - Method in interface alluxio.grpc.WriteRequestOrBuilder
.alluxio.grpc.block.Chunk chunk = 2;
hasChunkSize() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 chunk_size = 5;
hasChunkSize() - Method in class alluxio.grpc.ReadRequest
optional int64 chunk_size = 5;
hasChunkSize() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 chunk_size = 5;
hasChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, the server should send packets in the specified packet size.
hasChunkSize() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
If set, the server should send packets in the specified packet size.
hasChunkSize() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
If set, the server should send packets in the specified packet size.
hasClientId() - Method in class alluxio.grpc.SaslMessage.Builder
optional string clientId = 3;
hasClientId() - Method in class alluxio.grpc.SaslMessage
optional string clientId = 3;
hasClientId() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional string clientId = 3;
hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string clusterConfigHash = 1;
hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
optional string clusterConfigHash = 1;
hasClusterConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
optional string clusterConfigHash = 1;
hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string clusterConfigHash = 3;
hasClusterConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
optional string clusterConfigHash = 3;
hasClusterConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional string clusterConfigHash = 3;
hasClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 clusterConfigLastUpdateTime = 5;
hasClusterConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
optional int64 clusterConfigLastUpdateTime = 5;
hasClusterConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional int64 clusterConfigLastUpdateTime = 5;
hasClusterId() - Method in class alluxio.grpc.MasterInfo.Builder
optional string clusterId = 11;
hasClusterId() - Method in class alluxio.grpc.MasterInfo
optional string clusterId = 11;
hasClusterId() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string clusterId = 11;
hasClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
optional string cluster_id = 1;
hasClusterId() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
optional string cluster_id = 1;
hasClusterId() - Method in interface alluxio.proto.journal.Meta.ClusterInfoEntryOrBuilder
optional string cluster_id = 1;
hasClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
hasClusterInfo() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
hasClusterInfo() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
hasCmdConfig() - Method in class alluxio.grpc.SubmitRequest.Builder
optional bytes cmdConfig = 1;
hasCmdConfig() - Method in class alluxio.grpc.SubmitRequest
optional bytes cmdConfig = 1;
hasCmdConfig() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
optional bytes cmdConfig = 1;
hasCmdProgress() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
hasCmdProgress() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
hasCmdProgress() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
hasCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
optional .alluxio.grpc.job.Status cmdStatus = 1;
hasCmdStatus() - Method in class alluxio.grpc.GetCmdStatusResponse
optional .alluxio.grpc.job.Status cmdStatus = 1;
hasCmdStatus() - Method in interface alluxio.grpc.GetCmdStatusResponseOrBuilder
optional .alluxio.grpc.job.Status cmdStatus = 1;
hasCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
hasCmdStatusBlock() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
hasCmdStatusBlock() - Method in interface alluxio.grpc.GetCmdStatusDetailedResponseOrBuilder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
hasCode() - Method in class alluxio.grpc.BlockStatus.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in class alluxio.grpc.BlockStatus
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in interface alluxio.grpc.BlockStatusOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in class alluxio.grpc.FileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in class alluxio.grpc.FileFailure
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in interface alluxio.grpc.FileFailureOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in class alluxio.grpc.LoadFileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in class alluxio.grpc.LoadFileFailure
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in class alluxio.grpc.RouteFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in class alluxio.grpc.RouteFailure
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasCode() - Method in interface alluxio.grpc.RouteFailureOrBuilder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
hasColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_name = 1;
hasColName() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional string col_name = 1;
hasColName() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional string col_name = 1;
hasColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_type = 2;
hasColType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional string col_type = 2;
hasColType() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional string col_type = 2;
hasColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required string column_name = 1;
hasColumnName() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
required string column_name = 1;
hasColumnName() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
required string column_name = 1;
hasCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
hasCommand() - Method in class alluxio.grpc.BlockHeartbeatPResponse
optional .alluxio.grpc.Command command = 1;
hasCommand() - Method in interface alluxio.grpc.BlockHeartbeatPResponseOrBuilder
optional .alluxio.grpc.Command command = 1;
hasCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
hasCommand() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
optional .alluxio.grpc.file.FileSystemCommand command = 1;
hasCommand() - Method in interface alluxio.grpc.FileSystemHeartbeatPResponseOrBuilder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
hasCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
hasCommand() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
hasCommand() - Method in interface alluxio.grpc.JobMasterHeartbeatPResponseOrBuilder
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
hasCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
optional .alluxio.grpc.meta.MetaCommand command = 1;
hasCommand() - Method in class alluxio.grpc.MasterHeartbeatPResponse
optional .alluxio.grpc.meta.MetaCommand command = 1;
hasCommand() - Method in interface alluxio.grpc.MasterHeartbeatPResponseOrBuilder
optional .alluxio.grpc.meta.MetaCommand command = 1;
hasCommand() - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
hasCommand() - Method in class alluxio.grpc.WriteRequest
.alluxio.grpc.block.WriteRequestCommand command = 1;
hasCommand() - Method in interface alluxio.grpc.WriteRequestOrBuilder
.alluxio.grpc.block.WriteRequestCommand command = 1;
hasCommandOptions() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
hasCommandOptions() - Method in class alluxio.grpc.FileSystemCommand
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
hasCommandOptions() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
hasCommandType() - Method in class alluxio.grpc.Command.Builder
optional .alluxio.grpc.CommandType commandType = 1;
hasCommandType() - Method in class alluxio.grpc.Command
optional .alluxio.grpc.CommandType commandType = 1;
hasCommandType() - Method in interface alluxio.grpc.CommandOrBuilder
optional .alluxio.grpc.CommandType commandType = 1;
hasCommandType() - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.CommandType commandType = 1;
hasCommandType() - Method in class alluxio.grpc.FileSystemCommand
optional .alluxio.grpc.CommandType commandType = 1;
hasCommandType() - Method in interface alluxio.grpc.FileSystemCommandOrBuilder
optional .alluxio.grpc.CommandType commandType = 1;
hasComment() - Method in class alluxio.grpc.table.Database.Builder
optional string comment = 7;
hasComment() - Method in class alluxio.grpc.table.Database
optional string comment = 7;
hasComment() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string comment = 7;
hasComment() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string comment = 4;
hasComment() - Method in class alluxio.grpc.table.FieldSchema
optional string comment = 4;
hasComment() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string comment = 4;
hasCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in class alluxio.grpc.CheckAccessPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in interface alluxio.grpc.CheckAccessPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.CheckConsistencyPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.CheckConsistencyPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.CompleteFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
hasCommonOptions() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
hasCommonOptions() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
hasCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
hasCommonOptions() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
hasCommonOptions() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
hasCommonOptions() - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in class alluxio.grpc.DeletePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in class alluxio.grpc.ExistsPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.FreePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in class alluxio.grpc.GetStatusPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
hasCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.ListStatusPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in class alluxio.grpc.LoadMetadataPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in class alluxio.grpc.MountPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
hasCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.OpenFilePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
hasCommonOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.RenamePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.SetAclPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
hasCommonOptions() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
hasCommonOptions() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
hasCommonOptions() - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.grpc.UnmountPOptions
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.grpc.UnmountPOptionsOrBuilder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
hasCommonOptions() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
hasCommonOptions() - Method in interface alluxio.proto.client.Cache.PRocksPageStoreOptionsOrBuilder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
hasCompleted() - Method in class alluxio.grpc.FileInfo.Builder
optional bool completed = 8;
hasCompleted() - Method in class alluxio.grpc.FileInfo
optional bool completed = 8;
hasCompleted() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool completed = 8;
hasCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool completed = 10;
hasCompleted() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool completed = 10;
hasCompleted() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool completed = 10;
hasCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool completed = 4;
hasCompleted() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional bool completed = 4;
hasCompleted() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional bool completed = 4;
hasCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
hasCompleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
hasCompleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
hasConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
hasConstraint() - Method in class alluxio.grpc.table.ReadTablePRequest
optional .alluxio.grpc.table.Constraint constraint = 3;
hasConstraint() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional .alluxio.grpc.table.Constraint constraint = 3;
hasContainerHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string containerHost = 7;
hasContainerHost() - Method in class alluxio.grpc.WorkerNetAddress
optional string containerHost = 7;
hasContainerHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string containerHost = 7;
hasContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
hasContainerId() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
optional int64 container_id = 1;
hasContainerId() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
optional int64 container_id = 1;
hasContentHash() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional string contentHash = 4;
hasContentHash() - Method in class alluxio.grpc.CompleteFilePOptions
optional string contentHash = 4;
hasContentHash() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional string contentHash = 4;
hasContentHash() - Method in class alluxio.grpc.FileInfo.Builder
optional string contentHash = 34;
hasContentHash() - Method in class alluxio.grpc.FileInfo
optional string contentHash = 34;
hasContentHash() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string contentHash = 34;
hasContentHash() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional string content_hash = 1;
hasContentHash() - Method in class alluxio.grpc.UfsFileStatus
optional string content_hash = 1;
hasContentHash() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
optional string content_hash = 1;
hasContentHash() - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
hasContentHash() - Method in class alluxio.grpc.WriteResponse
Errors will be handled by standard gRPC stream APIs.
hasContentHash() - Method in interface alluxio.grpc.WriteResponseOrBuilder
Errors will be handled by standard gRPC stream APIs.
hasContentLength() - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 content_length = 2;
hasContentLength() - Method in class alluxio.grpc.UfsFileStatus
optional int64 content_length = 2;
hasContentLength() - Method in interface alluxio.grpc.UfsFileStatusOrBuilder
optional int64 content_length = 2;
hasCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
hasCopyJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
hasCopyJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
hasCount() - Method in class alluxio.grpc.StatusSummary.Builder
optional int64 count = 2;
hasCount() - Method in class alluxio.grpc.StatusSummary
optional int64 count = 2;
hasCount() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
optional int64 count = 2;
hasCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional bool createAncestors = 2;
hasCreateAncestors() - Method in class alluxio.grpc.LoadMetadataPOptions
optional bool createAncestors = 2;
hasCreateAncestors() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional bool createAncestors = 2;
hasCreatedAt() - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 created_at = 3;
hasCreatedAt() - Method in class alluxio.grpc.PolicyInfo
optional int64 created_at = 3;
hasCreatedAt() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional int64 created_at = 3;
hasCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 created_at = 3;
hasCreatedAt() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional int64 created_at = 3;
hasCreatedAt() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional int64 created_at = 3;
hasCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
hasCreateUfsFileOptions() - Method in class alluxio.grpc.WriteRequestCommand
Cancel, close and error will be handled by standard gRPC stream APIs.
hasCreateUfsFileOptions() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
Cancel, close and error will be handled by standard gRPC stream APIs.
hasCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
hasCreateUfsFileOptions() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
This is only applicable for ufs writes.
hasCreateUfsFileOptions() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
This is only applicable for ufs writes.
hasCreationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 creationTimeMs = 7;
hasCreationTimeMs() - Method in class alluxio.grpc.FileInfo
optional int64 creationTimeMs = 7;
hasCreationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 creationTimeMs = 7;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 creation_time_ms = 6;
hasCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 creation_time_ms = 2;
hasCreationTimeMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 creation_time_ms = 2;
hasCreationTimeMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 creation_time_ms = 2;
hasData() - Method in class alluxio.grpc.Chunk.Builder
optional bytes data = 1;
hasData() - Method in class alluxio.grpc.Chunk
optional bytes data = 1;
hasData() - Method in interface alluxio.grpc.ChunkOrBuilder
optional bytes data = 1;
hasData() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated. 
hasData() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated. 
hasData() - Method in interface alluxio.grpc.DownloadSnapshotPResponseOrBuilder
Deprecated. 
hasData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
hasData() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
hasData() - Method in interface alluxio.grpc.table.ColumnStatisticsInfoOrBuilder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
hasData() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated. 
hasData() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated. 
hasData() - Method in interface alluxio.grpc.UploadSnapshotPRequestOrBuilder
Deprecated. 
hasDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
optional string database = 1;
hasDatabase() - Method in class alluxio.grpc.table.GetAllTablesPRequest
optional string database = 1;
hasDatabase() - Method in interface alluxio.grpc.table.GetAllTablesPRequestOrBuilder
optional string database = 1;
hasDataPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 dataPort = 3;
hasDataPort() - Method in class alluxio.grpc.WorkerNetAddress
optional int32 dataPort = 3;
hasDataPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional int32 dataPort = 3;
hasDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
hasDateStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
hasDateStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
hasDaysSinceEpoch() - Method in class alluxio.grpc.table.Date.Builder
required int64 days_since_epoch = 1;
hasDaysSinceEpoch() - Method in class alluxio.grpc.table.Date
required int64 days_since_epoch = 1;
hasDaysSinceEpoch() - Method in interface alluxio.grpc.table.DateOrBuilder
required int64 days_since_epoch = 1;
hasDb() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
hasDb() - Method in class alluxio.grpc.table.GetDatabasePResponse
optional .alluxio.grpc.table.Database db = 1;
hasDb() - Method in interface alluxio.grpc.table.GetDatabasePResponseOrBuilder
optional .alluxio.grpc.table.Database db = 1;
hasDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string db_name = 4;
hasDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string db_name = 4;
hasDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string db_name = 4;
hasDbName() - Method in class alluxio.grpc.table.Database.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.Database
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.DetachDatabasePRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.DetachDatabasePRequestOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetDatabasePRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.GetDatabasePRequestOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.GetTablePRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string db_name = 3;
hasDbName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional string db_name = 3;
hasDbName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional string db_name = 3;
hasDbName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.ReadTablePRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.SyncDatabasePRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.SyncDatabasePRequestOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.TableInfo
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.TransformJobInfo
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string db_name = 1;
hasDbName() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string db_name = 1;
hasDbName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string db_name = 1;
hasDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
hasDecimalStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
hasDecimalStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
hasDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 decommissionedWorkerNum = 8;
hasDecommissionedWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
optional int32 decommissionedWorkerNum = 8;
hasDecommissionedWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int32 decommissionedWorkerNum = 8;
hasDefaultAcl() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
hasDefaultAcl() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
hasDefaultAcl() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
hasDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
hasDefaultAcl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
hasDefaultAcl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
hasDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
hasDefaultAcl() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
hasDefaultAcl() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
hasDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
hasDefaultAcl() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
hasDefaultAcl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
hasDefinition() - Method in class alluxio.grpc.table.Transformation.Builder
optional string definition = 2;
hasDefinition() - Method in class alluxio.grpc.table.Transformation
optional string definition = 2;
hasDefinition() - Method in interface alluxio.grpc.table.TransformationOrBuilder
optional string definition = 2;
hasDefinition() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string definition = 3;
hasDefinition() - Method in class alluxio.grpc.table.TransformJobInfo
optional string definition = 3;
hasDefinition() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string definition = 3;
hasDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string definition = 3;
hasDefinition() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string definition = 3;
hasDefinition() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string definition = 3;
hasDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
hasDeleteBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
hasDeleteBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
hasDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
hasDeleteFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
hasDeleteFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
hasDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool deleteMountPoint = 6;
hasDeleteMountPoint() - Method in class alluxio.grpc.DeletePOptions
optional bool deleteMountPoint = 6;
hasDeleteMountPoint() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool deleteMountPoint = 6;
hasDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
hasDeleteMountPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
hasDeleteMountPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
hasDescription() - Method in class alluxio.grpc.JobInfo.Builder
optional string description = 13;
hasDescription() - Method in class alluxio.grpc.JobInfo
optional string description = 13;
hasDescription() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string description = 13;
hasDescription() - Method in class alluxio.grpc.table.Database.Builder
optional string description = 2;
hasDescription() - Method in class alluxio.grpc.table.Database
optional string description = 2;
hasDescription() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string description = 2;
hasDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool directChildrenLoaded = 13;
hasDirectChildrenLoaded() - Method in class alluxio.grpc.SetAttributePOptions
optional bool directChildrenLoaded = 13;
hasDirectChildrenLoaded() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool directChildrenLoaded = 13;
hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool direct_children_loaded = 12;
hasDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool direct_children_loaded = 12;
hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool direct_children_loaded = 3;
hasDirectChildrenLoaded() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional bool direct_children_loaded = 3;
hasDirectChildrenLoaded() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional bool direct_children_loaded = 3;
hasDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions.Builder
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
hasDisableAreDescendantsLoadedCheck() - Method in class alluxio.grpc.ListStatusPOptions
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
hasDisableAreDescendantsLoadedCheck() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
hasDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
optional .alluxio.grpc.journal.JournalDomain domain = 1;
hasDomain() - Method in class alluxio.grpc.GetQuorumInfoPResponse
optional .alluxio.grpc.journal.JournalDomain domain = 1;
hasDomain() - Method in interface alluxio.grpc.GetQuorumInfoPResponseOrBuilder
optional .alluxio.grpc.journal.JournalDomain domain = 1;
hasDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string domainSocketPath = 5;
hasDomainSocketPath() - Method in class alluxio.grpc.WorkerNetAddress
optional string domainSocketPath = 5;
hasDomainSocketPath() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string domainSocketPath = 5;
hasDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
hasDoubleStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
hasDoubleStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
hasDoubleType() - Method in class alluxio.grpc.table.Value.Builder
double double_type = 2;
hasDoubleType() - Method in class alluxio.grpc.table.Value
double double_type = 2;
hasDoubleType() - Method in interface alluxio.grpc.table.ValueOrBuilder
double double_type = 2;
hasDoubleValue() - Method in class alluxio.grpc.MetricValue.Builder
optional double doubleValue = 1;
hasDoubleValue() - Method in class alluxio.grpc.MetricValue
optional double doubleValue = 1;
hasDoubleValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
optional double doubleValue = 1;
hasDst() - Method in class alluxio.grpc.Route.Builder
required string dst = 2;
hasDst() - Method in class alluxio.grpc.Route
required string dst = 2;
hasDst() - Method in interface alluxio.grpc.RouteOrBuilder
required string dst = 2;
hasDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string dst = 2;
hasDst() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string dst = 2;
hasDst() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string dst = 2;
hasDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string dst = 2;
hasDst() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string dst = 2;
hasDst() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string dst = 2;
hasDstPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string dstPath = 3;
hasDstPath() - Method in class alluxio.grpc.AddPolicyPOptions
optional string dstPath = 3;
hasDstPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string dstPath = 3;
hasDstPath() - Method in class alluxio.grpc.RenamePRequest.Builder
the destination path
hasDstPath() - Method in class alluxio.grpc.RenamePRequest
the destination path
hasDstPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
the destination path
hasDstPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
Deprecated, use new_parent_id/new_name instead
hasDstPath() - Method in class alluxio.proto.journal.File.RenameEntry
Deprecated, use new_parent_id/new_name instead
hasDstPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
Deprecated, use new_parent_id/new_name instead
hasDuration() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 duration = 6;
hasDuration() - Method in class alluxio.grpc.CmdSummary
optional int64 duration = 6;
hasDuration() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional int64 duration = 6;
hasEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 end_time = 9;
hasEndTime() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional int64 end_time = 9;
hasEndTime() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional int64 end_time = 9;
hasEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 end_time = 8;
hasEndTime() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional int64 end_time = 8;
hasEndTime() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional int64 end_time = 8;
hasEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 end_time = 9;
hasEndTime() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional int64 end_time = 9;
hasEndTime() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional int64 end_time = 9;
hasEntryCount() - Method in class alluxio.grpc.BackupPStatus.Builder
optional int64 entryCount = 5;
hasEntryCount() - Method in class alluxio.grpc.BackupPStatus
optional int64 entryCount = 5;
hasEntryCount() - Method in interface alluxio.grpc.BackupPStatusOrBuilder
optional int64 entryCount = 5;
hasEof() - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
hasEof() - Method in class alluxio.grpc.SnapshotData
Deprecated. 
hasEof() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
Deprecated. 
hasEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
hasEof() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional bool eof = 5;
hasEof() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional bool eof = 5;
hasEquatable() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
hasEquatable() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.EquatableValueSet equatable = 2;
hasEquatable() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
hasErrorMessage() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorMessage = 7;
hasErrorMessage() - Method in class alluxio.grpc.ActionInfo
optional string errorMessage = 7;
hasErrorMessage() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string errorMessage = 7;
hasErrorMessage() - Method in class alluxio.grpc.CmdSummary.Builder
optional string errorMessage = 7;
hasErrorMessage() - Method in class alluxio.grpc.CmdSummary
optional string errorMessage = 7;
hasErrorMessage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional string errorMessage = 7;
hasErrorMessage() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorMessage = 2;
hasErrorMessage() - Method in class alluxio.grpc.JobInfo
optional string errorMessage = 2;
hasErrorMessage() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string errorMessage = 2;
hasErrorMsg() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorMsg = 5;
hasErrorMsg() - Method in class alluxio.grpc.JobProgress
optional string errorMsg = 5;
hasErrorMsg() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional string errorMsg = 5;
hasErrorType() - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorType = 6;
hasErrorType() - Method in class alluxio.grpc.ActionInfo
optional string errorType = 6;
hasErrorType() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string errorType = 6;
hasErrorType() - Method in class alluxio.grpc.ErrorInfo.Builder
optional .alluxio.grpc.ErrorType errorType = 1;
hasErrorType() - Method in class alluxio.grpc.ErrorInfo
optional .alluxio.grpc.ErrorType errorType = 1;
hasErrorType() - Method in interface alluxio.grpc.ErrorInfoOrBuilder
optional .alluxio.grpc.ErrorType errorType = 1;
hasErrorType() - Method in class alluxio.grpc.JobInfo.Builder
optional string errorType = 15;
hasErrorType() - Method in class alluxio.grpc.JobInfo
optional string errorType = 15;
hasErrorType() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string errorType = 15;
hasErrorType() - Method in class alluxio.grpc.JobProgress.Builder
optional string errorType = 6;
hasErrorType() - Method in class alluxio.grpc.JobProgress
optional string errorType = 6;
hasErrorType() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional string errorType = 6;
hasExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions.Builder
Mount info will be excluded from the list status response if this field is set to true.
hasExcludeMountInfo() - Method in class alluxio.grpc.ListStatusPOptions
Mount info will be excluded from the list status response if this field is set to true.
hasExcludeMountInfo() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
Mount info will be excluded from the list status response if this field is set to true.
hasExists() - Method in class alluxio.grpc.ExistsPResponse.Builder
optional bool exists = 1;
hasExists() - Method in class alluxio.grpc.ExistsPResponse
optional bool exists = 1;
hasExists() - Method in interface alluxio.grpc.ExistsPResponseOrBuilder
optional bool exists = 1;
hasExists() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional bool exists = 3;
hasExists() - Method in class alluxio.grpc.SnapshotMetadata
optional bool exists = 3;
hasExists() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
optional bool exists = 3;
hasExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 expiryMs = 3;
hasExpiryMs() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional int64 expiryMs = 3;
hasExpiryMs() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional int64 expiryMs = 3;
hasExtended() - Method in class alluxio.security.authorization.AccessControlList
 
hasExtended() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
hasFailure() - Method in class alluxio.master.job.CopyJob
 
hasFailure() - Method in class alluxio.master.job.DoraLoadJob
 
hasFailure() - Method in class alluxio.master.job.LoadJob
 
hasFailure() - Method in class alluxio.master.job.MoveJob
 
hasFailure() - Method in interface alluxio.scheduler.job.Job
 
hasFile(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
hasFile() - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
hasFile() - Method in class alluxio.grpc.FileFailure
required .alluxio.grpc.block.File file = 1;
hasFile() - Method in interface alluxio.grpc.FileFailureOrBuilder
required .alluxio.grpc.block.File file = 1;
hasFileCount() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileCount = 2;
hasFileCount() - Method in class alluxio.grpc.JobProgress
optional int64 fileCount = 2;
hasFileCount() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 fileCount = 2;
hasFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
The total number of files in the listing directory, (i.e.
hasFileCount() - Method in class alluxio.grpc.ListStatusPartialPResponse
The total number of files in the listing directory, (i.e.
hasFileCount() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
The total number of files in the listing directory, (i.e.
hasFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string file_date_pattern = 6;
hasFileDatePattern() - Method in class alluxio.grpc.AddPolicyPOptions
optional string file_date_pattern = 6;
hasFileDatePattern() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string file_date_pattern = 6;
hasFileId() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 fileId = 1;
hasFileId() - Method in class alluxio.grpc.FileInfo
optional int64 fileId = 1;
hasFileId() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 fileId = 1;
hasFileId() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
the id of the file
hasFileId() - Method in class alluxio.grpc.GetFileInfoPRequest
the id of the file
hasFileId() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
the id of the file
hasFileId() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
optional int64 fileId = 1;
hasFileId() - Method in class alluxio.grpc.GetFilePathPRequest
optional int64 fileId = 1;
hasFileId() - Method in interface alluxio.grpc.GetFilePathPRequestOrBuilder
optional int64 fileId = 1;
hasFileId() - Method in class alluxio.grpc.PersistFile.Builder
optional int64 fileId = 1;
hasFileId() - Method in class alluxio.grpc.PersistFile
optional int64 fileId = 1;
hasFileId() - Method in interface alluxio.grpc.PersistFileOrBuilder
optional int64 fileId = 1;
hasFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
hasFileId() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
optional int64 file_id = 1;
hasFileId() - Method in interface alluxio.proto.journal.File.AsyncPersistRequestEntryOrBuilder
optional int64 file_id = 1;
hasFileInfo() - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in class alluxio.grpc.CreateFilePResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in class alluxio.grpc.GetFileInfoPResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in interface alluxio.grpc.GetFileInfoPResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in class alluxio.grpc.GetStatusPResponse
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in interface alluxio.grpc.GetStatusPResponseOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFileInfo() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
hasFilePath() - Method in class alluxio.grpc.ActionInfo.Builder
optional string filePath = 4;
hasFilePath() - Method in class alluxio.grpc.ActionInfo
optional string filePath = 4;
hasFilePath() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional string filePath = 4;
hasFilePath() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string filePath = 3;
hasFilePath() - Method in class alluxio.grpc.GetActionInfoRequest
optional string filePath = 3;
hasFilePath() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string filePath = 3;
hasFilePath() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePath = 3;
hasFilePath() - Method in class alluxio.grpc.JobStatusBlock
optional string filePath = 3;
hasFilePath() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional string filePath = 3;
hasFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePathFailed = 4;
hasFilePathFailed() - Method in class alluxio.grpc.JobStatusBlock
optional string filePathFailed = 4;
hasFilePathFailed() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional string filePathFailed = 4;
hasFileSize() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileSize = 3;
hasFileSize() - Method in class alluxio.grpc.JobProgress
optional int64 fileSize = 3;
hasFileSize() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 fileSize = 3;
hasFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int32 files_skipped = 3;
hasFilesSkipped() - Method in class alluxio.grpc.LoadFileResponse
optional int32 files_skipped = 3;
hasFilesSkipped() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
optional int32 files_skipped = 3;
hasFilter() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string filter = 5;
hasFilter() - Method in class alluxio.grpc.AddPolicyPOptions
optional string filter = 5;
hasFilter() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string filter = 5;
hasFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
hasFilter() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional .alluxio.proto.journal.FileFilter filter = 12;
hasFilter() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional .alluxio.proto.journal.FileFilter filter = 12;
hasFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
hasFilter() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional .alluxio.proto.journal.FileFilter filter = 12;
hasFilter() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional .alluxio.proto.journal.FileFilter filter = 12;
hasFlush() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool flush = 5;
hasFlush() - Method in class alluxio.grpc.WriteRequestCommand
optional bool flush = 5;
hasFlush() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional bool flush = 5;
hasFolder() - Method in class alluxio.grpc.FileInfo.Builder
optional bool folder = 9;
hasFolder() - Method in class alluxio.grpc.FileInfo
optional bool folder = 9;
hasFolder() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool folder = 9;
hasForced() - Method in class alluxio.grpc.FreePOptions.Builder
optional bool forced = 2;
hasForced() - Method in class alluxio.grpc.FreePOptions
optional bool forced = 2;
hasForced() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
optional bool forced = 2;
hasFormat() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
hasFormat() - Method in class alluxio.grpc.GetJobProgressPResponse
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
hasFormat() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
hasFormat() - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
hasFormat() - Method in class alluxio.grpc.JobProgressPOptions
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
hasFormat() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
hasFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 freeBytes = 3;
hasFreeBytes() - Method in class alluxio.grpc.BlockMasterInfo
optional int64 freeBytes = 3;
hasFreeBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int64 freeBytes = 3;
hasGroup() - Method in class alluxio.grpc.FileInfo.Builder
optional string group = 17;
hasGroup() - Method in class alluxio.grpc.FileInfo
optional string group = 17;
hasGroup() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string group = 17;
hasGroup() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string group = 4;
hasGroup() - Method in class alluxio.grpc.SetAttributePOptions
optional string group = 4;
hasGroup() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional string group = 4;
hasGroup() - Method in class alluxio.grpc.UfsStatus.Builder
optional string group = 5;
hasGroup() - Method in class alluxio.grpc.UfsStatus
optional string group = 5;
hasGroup() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string group = 5;
hasGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
hasGroup() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string group = 3;
hasGroup() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string group = 3;
hasGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
hasGroup() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string group = 9;
hasGroup() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string group = 9;
hasGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
hasGroup() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string group = 15;
hasGroup() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string group = 15;
hasGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
hasGroup() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string group = 7;
hasGroup() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string group = 7;
hasGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string group = 10;
hasGroup() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string group = 10;
hasGroup() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string group = 10;
hasGroupBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits groupBits = 2;
hasGroupBits() - Method in class alluxio.grpc.PMode
required .alluxio.grpc.Bits groupBits = 2;
hasGroupBits() - Method in interface alluxio.grpc.PModeOrBuilder
required .alluxio.grpc.Bits groupBits = 2;
hash() - Method in class alluxio.AlluxioURI
Computes the hash of this URI, with SHA-256, or MD5, or simple hashCode().
hash(String) - Static method in class alluxio.AlluxioURI
Computes the hash of this URI, with SHA-256, or MD5, or simple hashCode().
hash() - Method in interface alluxio.conf.AlluxioConfiguration
 
hash() - Method in class alluxio.conf.AlluxioProperties
 
hash() - Static method in class alluxio.conf.Configuration
 
Hash - Class in alluxio.conf
A hex encoded MD5 hash of the cluster or path configurations.
Hash(Supplier<Stream<byte[]>>) - Constructor for class alluxio.conf.Hash
 
hash() - Method in class alluxio.conf.InstancedConfiguration
 
hash() - Method in class alluxio.master.meta.PathProperties
 
hash(String) - Static method in class alluxio.s3.signature.StringToSignProducer
Compute a hash for provided string.
hash(int, String) - Static method in class alluxio.util.URIUtils
Hashes a string for a URI hash.
HashAllocator - Class in alluxio.client.file.cache.allocator
An implementation of Allocator base on the hash of the file id for local cache.
HashAllocator(List<PageStoreDir>) - Constructor for class alluxio.client.file.cache.allocator.HashAllocator
 
HashAllocator(List<PageStoreDir>, Function<String, Integer>) - Constructor for class alluxio.client.file.cache.allocator.HashAllocator
 
hasHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool has_direct_children_loaded = 13;
hasHasDirectChildrenLoaded() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool has_direct_children_loaded = 13;
hasHasDirectChildrenLoaded() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool has_direct_children_loaded = 13;
hashAsLong(String) - Static method in class alluxio.util.HashUtils
Hash the give obj as long with given HASH_FUNCTION.
hashAsStringMD5(String) - Static method in class alluxio.util.HashUtils
MD5 Hash the given obj as string.
HashBasedWorkerAssignPolicy - Class in alluxio.master.job
Policy which employs Hash-Based algorithm to select worker from given workers set.
HashBasedWorkerAssignPolicy() - Constructor for class alluxio.master.job.HashBasedWorkerAssignPolicy
 
hashCode() - Method in class alluxio.AlluxioURI
 
hashCode() - Method in class alluxio.cli.docgen.MetricsDocGenerator.FileWriterKey
 
hashCode() - Method in class alluxio.cli.fs.command.FileLocation
 
hashCode() - Method in class alluxio.cli.LogLevel.TargetInfo
 
hashCode() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
hashCode() - Method in class alluxio.client.file.cache.CacheUsage.DirPartition
 
hashCode() - Method in class alluxio.client.file.cache.CacheUsage.FilePartition
 
hashCode() - Method in class alluxio.client.file.cache.CacheUsage.ScopePartition
 
hashCode() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
hashCode() - Method in class alluxio.client.file.cache.PageId
 
hashCode() - Method in class alluxio.client.file.cache.PageInfo
 
hashCode() - Method in class alluxio.client.file.CacheContext
 
hashCode() - Method in class alluxio.client.file.FileSystemCache.Key
 
hashCode() - Method in class alluxio.client.file.FileSystemContext.ClientPoolKey
 
hashCode() - Method in class alluxio.client.file.options.InStreamOptions
 
hashCode() - Method in class alluxio.client.file.options.OutStreamOptions
 
hashCode() - Method in class alluxio.client.file.URIStatus
 
hashCode() - Method in class alluxio.client.hive.HiveCacheContext
 
hashCode() - Method in class alluxio.client.quota.CacheQuota
 
hashCode() - Method in class alluxio.client.quota.CacheScope
 
hashCode() - Method in class alluxio.collections.DelegatingSet
 
hashCode() - Method in class alluxio.collections.Pair
 
hashCode() - Method in class alluxio.collections.TwoKeyConcurrentMap
The hashCode implementation for this map simply uses the superclass's.
hashCode() - Method in class alluxio.conf.PropertyKey
 
hashCode() - Method in class alluxio.conf.Source
 
hashCode() - Method in class alluxio.fuse.options.FuseCliOptions
 
hashCode() - Method in class alluxio.fuse.options.MountCliOptions
 
hashCode() - Method in class alluxio.fuse.options.MountOptions
 
hashCode() - Method in class alluxio.grpc.ActionInfo
 
hashCode() - Method in class alluxio.grpc.AddPolicyPOptions
 
hashCode() - Method in class alluxio.grpc.AddPolicyPRequest
 
hashCode() - Method in class alluxio.grpc.AddPolicyPResponse
 
hashCode() - Method in class alluxio.grpc.AddQuorumServerRequest
 
hashCode() - Method in class alluxio.grpc.AsyncCacheRequest
 
hashCode() - Method in class alluxio.grpc.AsyncCacheResponse
 
hashCode() - Method in class alluxio.grpc.BackupPOptions
 
hashCode() - Method in class alluxio.grpc.BackupPRequest
 
hashCode() - Method in class alluxio.grpc.BackupPStatus
 
hashCode() - Method in class alluxio.grpc.BackupStatusPRequest
 
hashCode() - Method in class alluxio.grpc.Block
 
hashCode() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
hashCode() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
hashCode() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
hashCode() - Method in class alluxio.grpc.BlockIdList
 
hashCode() - Method in class alluxio.grpc.BlockInfo
 
hashCode() - Method in class alluxio.grpc.BlockLocation
 
hashCode() - Method in class alluxio.grpc.BlockMasterInfo
 
hashCode() - Method in class alluxio.grpc.BlockStatus
 
hashCode() - Method in class alluxio.grpc.BlockStoreLocationProto
 
hashCode() - Method in class alluxio.grpc.BuildVersion
 
hashCode() - Method in class alluxio.grpc.CacheRequest
 
hashCode() - Method in class alluxio.grpc.CacheResponse
 
hashCode() - Method in class alluxio.grpc.CancelPOptions
 
hashCode() - Method in class alluxio.grpc.CancelPRequest
 
hashCode() - Method in class alluxio.grpc.CancelPResponse
 
hashCode() - Method in class alluxio.grpc.CancelTaskCommand
 
hashCode() - Method in class alluxio.grpc.CheckAccessPOptions
 
hashCode() - Method in class alluxio.grpc.CheckAccessPRequest
 
hashCode() - Method in class alluxio.grpc.CheckAccessPResponse
 
hashCode() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
hashCode() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
hashCode() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
hashCode() - Method in class alluxio.grpc.CheckpointPOptions
 
hashCode() - Method in class alluxio.grpc.CheckpointPResponse
 
hashCode() - Method in class alluxio.grpc.CheckRequest
 
hashCode() - Method in class alluxio.grpc.CheckResponse
 
hashCode() - Method in class alluxio.grpc.Chunk
 
hashCode() - Method in class alluxio.grpc.ClearMetricsPRequest
 
hashCode() - Method in class alluxio.grpc.ClearMetricsPResponse
 
hashCode() - Method in class alluxio.grpc.ClearMetricsRequest
 
hashCode() - Method in class alluxio.grpc.ClearMetricsResponse
 
hashCode() - Method in class alluxio.grpc.ClientMetrics
 
hashCode() - Method in class alluxio.grpc.CmdProgress
 
hashCode() - Method in class alluxio.grpc.CmdStatusBlock
 
hashCode() - Method in class alluxio.grpc.CmdSummary
 
hashCode() - Method in class alluxio.grpc.Command
 
hashCode() - Method in class alluxio.grpc.CommitBlockPOptions
 
hashCode() - Method in class alluxio.grpc.CommitBlockPRequest
 
hashCode() - Method in class alluxio.grpc.CommitBlockPResponse
 
hashCode() - Method in class alluxio.grpc.CompleteFilePOptions
 
hashCode() - Method in class alluxio.grpc.CompleteFilePRequest
 
hashCode() - Method in class alluxio.grpc.CompleteFilePResponse
 
hashCode() - Method in class alluxio.grpc.ConfigCheckReport
 
hashCode() - Method in class alluxio.grpc.ConfigProperties
 
hashCode() - Method in class alluxio.grpc.ConfigProperty
 
hashCode() - Method in class alluxio.grpc.CopyJobPOptions
 
hashCode() - Method in class alluxio.grpc.CopyRequest
 
hashCode() - Method in class alluxio.grpc.CopyResponse
 
hashCode() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
hashCode() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
hashCode() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
hashCode() - Method in class alluxio.grpc.CreateFilePOptions
 
hashCode() - Method in class alluxio.grpc.CreateFilePRequest
 
hashCode() - Method in class alluxio.grpc.CreateFilePResponse
 
hashCode() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
hashCode() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
hashCode() - Method in class alluxio.grpc.DeletePOptions
 
hashCode() - Method in class alluxio.grpc.DeletePRequest
 
hashCode() - Method in class alluxio.grpc.DeletePResponse
 
hashCode() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
hashCode() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
hashCode() - Method in class alluxio.grpc.ErrorInfo
 
hashCode() - Method in class alluxio.grpc.ExistsPOptions
 
hashCode() - Method in class alluxio.grpc.ExistsPRequest
 
hashCode() - Method in class alluxio.grpc.ExistsPResponse
 
hashCode() - Method in class alluxio.grpc.File
 
hashCode() - Method in class alluxio.grpc.FileBlockInfo
 
hashCode() - Method in class alluxio.grpc.FileFailure
 
hashCode() - Method in class alluxio.grpc.FileInfo
 
hashCode() - Method in class alluxio.grpc.FileSystemCommand
 
hashCode() - Method in class alluxio.grpc.FileSystemCommandOptions
 
hashCode() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
hashCode() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
hashCode() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
hashCode() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
hashCode() - Method in class alluxio.grpc.FreePOptions
 
hashCode() - Method in class alluxio.grpc.FreePRequest
 
hashCode() - Method in class alluxio.grpc.FreePResponse
 
hashCode() - Method in class alluxio.grpc.FreeWorkerRequest
 
hashCode() - Method in class alluxio.grpc.FreeWorkerResponse
 
hashCode() - Method in class alluxio.grpc.FsOpPId
 
hashCode() - Method in class alluxio.grpc.GetActionInfoOptions
 
hashCode() - Method in class alluxio.grpc.GetActionInfoRequest
 
hashCode() - Method in class alluxio.grpc.GetActionInfoResponse
 
hashCode() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
hashCode() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
hashCode() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
hashCode() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
hashCode() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
hashCode() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
hashCode() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
hashCode() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
hashCode() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
hashCode() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
hashCode() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
hashCode() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
hashCode() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
hashCode() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
hashCode() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
hashCode() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
hashCode() - Method in class alluxio.grpc.GetCmdStatusOptions
 
hashCode() - Method in class alluxio.grpc.GetCmdStatusRequest
 
hashCode() - Method in class alluxio.grpc.GetCmdStatusResponse
 
hashCode() - Method in class alluxio.grpc.GetConfigHashPOptions
 
hashCode() - Method in class alluxio.grpc.GetConfigHashPResponse
 
hashCode() - Method in class alluxio.grpc.GetConfigReportPOptions
 
hashCode() - Method in class alluxio.grpc.GetConfigReportPResponse
 
hashCode() - Method in class alluxio.grpc.GetConfigurationPOptions
 
hashCode() - Method in class alluxio.grpc.GetConfigurationPResponse
 
hashCode() - Method in class alluxio.grpc.GetFileInfoPOptions
 
hashCode() - Method in class alluxio.grpc.GetFileInfoPRequest
 
hashCode() - Method in class alluxio.grpc.GetFileInfoPResponse
 
hashCode() - Method in class alluxio.grpc.GetFilePathPRequest
 
hashCode() - Method in class alluxio.grpc.GetFilePathPResponse
 
hashCode() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
hashCode() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
hashCode() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
hashCode() - Method in class alluxio.grpc.GetJobProgressPRequest
 
hashCode() - Method in class alluxio.grpc.GetJobProgressPResponse
 
hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
hashCode() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
hashCode() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
hashCode() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
hashCode() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
hashCode() - Method in class alluxio.grpc.GetJobStatusPOptions
 
hashCode() - Method in class alluxio.grpc.GetJobStatusPRequest
 
hashCode() - Method in class alluxio.grpc.GetJobStatusPResponse
 
hashCode() - Method in class alluxio.grpc.GetMasterIdPOptions
 
hashCode() - Method in class alluxio.grpc.GetMasterIdPRequest
 
hashCode() - Method in class alluxio.grpc.GetMasterIdPResponse
 
hashCode() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
hashCode() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
hashCode() - Method in class alluxio.grpc.GetMetricsPOptions
 
hashCode() - Method in class alluxio.grpc.GetMetricsPResponse
 
hashCode() - Method in class alluxio.grpc.GetMountIdPRequest
 
hashCode() - Method in class alluxio.grpc.GetMountIdPResponse
 
hashCode() - Method in class alluxio.grpc.GetMountTablePRequest
 
hashCode() - Method in class alluxio.grpc.GetMountTablePResponse
 
hashCode() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
hashCode() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
hashCode() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
hashCode() - Method in class alluxio.grpc.GetNodeStatePRequest
 
hashCode() - Method in class alluxio.grpc.GetNodeStatePResponse
 
hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
hashCode() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
hashCode() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
hashCode() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
hashCode() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
hashCode() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
hashCode() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
hashCode() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
hashCode() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
hashCode() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
hashCode() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
hashCode() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
hashCode() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
hashCode() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
hashCode() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
hashCode() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
hashCode() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
hashCode() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
hashCode() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
hashCode() - Method in class alluxio.grpc.GetStatusPOptions
 
hashCode() - Method in class alluxio.grpc.GetStatusPRequest
 
hashCode() - Method in class alluxio.grpc.GetStatusPResponse
 
hashCode() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
hashCode() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
hashCode() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
hashCode() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
hashCode() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
hashCode() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
hashCode() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
hashCode() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
hashCode() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
hashCode() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
hashCode() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
hashCode() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
hashCode() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
hashCode() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
hashCode() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
hashCode() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
hashCode() - Method in class alluxio.grpc.GrpcChannel
 
hashCode() - Method in class alluxio.grpc.GrpcChannelKey
 
hashCode() - Method in class alluxio.grpc.GrpcServerAddress
 
hashCode() - Method in class alluxio.grpc.InconsistentProperties
 
hashCode() - Method in class alluxio.grpc.InconsistentProperty
 
hashCode() - Method in class alluxio.grpc.InconsistentPropertyValues
 
hashCode() - Method in class alluxio.grpc.JobCommand
 
hashCode() - Method in class alluxio.grpc.JobDescription
 
hashCode() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
hashCode() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
hashCode() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
hashCode() - Method in class alluxio.grpc.JobInfo
 
hashCode() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
hashCode() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
hashCode() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
hashCode() - Method in class alluxio.grpc.JobMasterStatus
 
hashCode() - Method in class alluxio.grpc.JobProgress
 
hashCode() - Method in class alluxio.grpc.JobProgressPOptions
 
hashCode() - Method in class alluxio.grpc.JobServiceSummary
 
hashCode() - Method in class alluxio.grpc.JobStatusBlock
 
hashCode() - Method in class alluxio.grpc.JobUnused
 
hashCode() - Method in class alluxio.grpc.JobWorkerHealth
 
hashCode() - Method in class alluxio.grpc.JournalQueryRequest
 
hashCode() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
hashCode() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
hashCode() - Method in class alluxio.grpc.ListAllPOptions
 
hashCode() - Method in class alluxio.grpc.ListAllPRequest
 
hashCode() - Method in class alluxio.grpc.ListAllPResponse
 
hashCode() - Method in class alluxio.grpc.ListPolicyPOptions
 
hashCode() - Method in class alluxio.grpc.ListPolicyPRequest
 
hashCode() - Method in class alluxio.grpc.ListPolicyPResponse
 
hashCode() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
hashCode() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
hashCode() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
hashCode() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
hashCode() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
hashCode() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
hashCode() - Method in class alluxio.grpc.ListStatusPOptions
 
hashCode() - Method in class alluxio.grpc.ListStatusPRequest
 
hashCode() - Method in class alluxio.grpc.ListStatusPResponse
 
hashCode() - Method in class alluxio.grpc.LoadFileFailure
 
hashCode() - Method in class alluxio.grpc.LoadFileRequest
 
hashCode() - Method in class alluxio.grpc.LoadFileResponse
 
hashCode() - Method in class alluxio.grpc.LoadJobPOptions
 
hashCode() - Method in class alluxio.grpc.LoadMetadataPOptions
 
hashCode() - Method in class alluxio.grpc.LoadRequest
 
hashCode() - Method in class alluxio.grpc.LoadResponse
 
hashCode() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
hashCode() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
hashCode() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
hashCode() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
hashCode() - Method in class alluxio.grpc.MasterInfo
 
hashCode() - Method in class alluxio.grpc.MasterVersion
 
hashCode() - Method in class alluxio.grpc.MessagingRequestHeader
 
hashCode() - Method in class alluxio.grpc.MessagingResponseHeader
 
hashCode() - Method in class alluxio.grpc.Metric
 
hashCode() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
hashCode() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
hashCode() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
hashCode() - Method in class alluxio.grpc.MetricValue
 
hashCode() - Method in class alluxio.grpc.MountPointInfo
 
hashCode() - Method in class alluxio.grpc.MountPOptions
 
hashCode() - Method in class alluxio.grpc.MountPRequest
 
hashCode() - Method in class alluxio.grpc.MountPResponse
 
hashCode() - Method in class alluxio.grpc.MoveBlockRequest
 
hashCode() - Method in class alluxio.grpc.MoveBlockResponse
 
hashCode() - Method in class alluxio.grpc.MoveJobPOptions
 
hashCode() - Method in class alluxio.grpc.MoveRequest
 
hashCode() - Method in class alluxio.grpc.MoveResponse
 
hashCode() - Method in class alluxio.grpc.NeedsSyncRequest
 
hashCode() - Method in class alluxio.grpc.NeedsSyncResponse
 
hashCode() - Method in class alluxio.grpc.NetAddress
 
hashCode() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
hashCode() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
hashCode() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
hashCode() - Method in class alluxio.grpc.OpenFilePOptions
 
hashCode() - Method in class alluxio.grpc.PAcl
 
hashCode() - Method in class alluxio.grpc.PAclEntry
 
hashCode() - Method in class alluxio.grpc.PersistCommandOptions
 
hashCode() - Method in class alluxio.grpc.PersistFile
 
hashCode() - Method in class alluxio.grpc.PMode
 
hashCode() - Method in class alluxio.grpc.PolicyInfo
 
hashCode() - Method in class alluxio.grpc.PolicyStatus
 
hashCode() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
hashCode() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
hashCode() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
hashCode() - Method in class alluxio.grpc.ProxyStatus
 
hashCode() - Method in class alluxio.grpc.QuorumServerInfo
 
hashCode() - Method in class alluxio.grpc.ReadRequest
 
hashCode() - Method in class alluxio.grpc.ReadResponse
 
hashCode() - Method in class alluxio.grpc.RegisterCommand
 
hashCode() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
hashCode() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
hashCode() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
hashCode() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
hashCode() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
hashCode() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
hashCode() - Method in class alluxio.grpc.RegisterMasterPOptions
 
hashCode() - Method in class alluxio.grpc.RegisterMasterPRequest
 
hashCode() - Method in class alluxio.grpc.RegisterMasterPResponse
 
hashCode() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
hashCode() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
hashCode() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
hashCode() - Method in class alluxio.grpc.RemoveBlockRequest
 
hashCode() - Method in class alluxio.grpc.RemoveBlockResponse
 
hashCode() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
hashCode() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
hashCode() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
hashCode() - Method in class alluxio.grpc.RemovePolicyPOptions
 
hashCode() - Method in class alluxio.grpc.RemovePolicyPRequest
 
hashCode() - Method in class alluxio.grpc.RemovePolicyPResponse
 
hashCode() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
hashCode() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
hashCode() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
hashCode() - Method in class alluxio.grpc.RenamePOptions
 
hashCode() - Method in class alluxio.grpc.RenamePRequest
 
hashCode() - Method in class alluxio.grpc.RenamePResponse
 
hashCode() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
hashCode() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
hashCode() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
hashCode() - Method in class alluxio.grpc.RetryInfo
 
hashCode() - Method in class alluxio.grpc.ReverseResolvePRequest
 
hashCode() - Method in class alluxio.grpc.ReverseResolvePResponse
 
hashCode() - Method in class alluxio.grpc.Route
 
hashCode() - Method in class alluxio.grpc.RouteFailure
 
hashCode() - Method in class alluxio.grpc.RunPOptions
 
hashCode() - Method in class alluxio.grpc.RunPRequest
 
hashCode() - Method in class alluxio.grpc.RunPResponse
 
hashCode() - Method in class alluxio.grpc.RunTaskCommand
 
hashCode() - Method in class alluxio.grpc.S3SyntaxOptions
 
hashCode() - Method in class alluxio.grpc.SaslMessage
 
hashCode() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
hashCode() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
hashCode() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
hashCode() - Method in class alluxio.grpc.SetAclPOptions
 
hashCode() - Method in class alluxio.grpc.SetAclPRequest
 
hashCode() - Method in class alluxio.grpc.SetAclPResponse
 
hashCode() - Method in class alluxio.grpc.SetAttributePOptions
 
hashCode() - Method in class alluxio.grpc.SetAttributePRequest
 
hashCode() - Method in class alluxio.grpc.SetAttributePResponse
 
hashCode() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
hashCode() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
hashCode() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
hashCode() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
hashCode() - Method in class alluxio.grpc.SnapshotData
 
hashCode() - Method in class alluxio.grpc.SnapshotMetadata
 
hashCode() - Method in class alluxio.grpc.StatusSummary
 
hashCode() - Method in class alluxio.grpc.StopJobPRequest
 
hashCode() - Method in class alluxio.grpc.StopJobPResponse
 
hashCode() - Method in class alluxio.grpc.StorageList
 
hashCode() - Method in class alluxio.grpc.SubmitJobPRequest
 
hashCode() - Method in class alluxio.grpc.SubmitJobPResponse
 
hashCode() - Method in class alluxio.grpc.SubmitOptions
 
hashCode() - Method in class alluxio.grpc.SubmitRequest
 
hashCode() - Method in class alluxio.grpc.SubmitResponse
 
hashCode() - Method in class alluxio.grpc.table.AllOrNoneSet
 
hashCode() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
hashCode() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
hashCode() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
hashCode() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
hashCode() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
hashCode() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
hashCode() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
hashCode() - Method in class alluxio.grpc.table.Constraint
 
hashCode() - Method in class alluxio.grpc.table.Database
 
hashCode() - Method in class alluxio.grpc.table.Date
 
hashCode() - Method in class alluxio.grpc.table.DateColumnStatsData
 
hashCode() - Method in class alluxio.grpc.table.Decimal
 
hashCode() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
hashCode() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
hashCode() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
hashCode() - Method in class alluxio.grpc.table.Domain
 
hashCode() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
hashCode() - Method in class alluxio.grpc.table.EquatableValueSet
 
hashCode() - Method in class alluxio.grpc.table.FieldSchema
 
hashCode() - Method in class alluxio.grpc.table.FileStatistics
 
hashCode() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
hashCode() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
hashCode() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
hashCode() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
hashCode() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
hashCode() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
hashCode() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
hashCode() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
hashCode() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
hashCode() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
hashCode() - Method in class alluxio.grpc.table.GetTablePRequest
 
hashCode() - Method in class alluxio.grpc.table.GetTablePResponse
 
hashCode() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
hashCode() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
hashCode() - Method in class alluxio.grpc.table.Layout
 
hashCode() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
hashCode() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
hashCode() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
hashCode() - Method in class alluxio.grpc.table.layout.hive.Storage
 
hashCode() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
hashCode() - Method in class alluxio.grpc.table.LayoutSpec
 
hashCode() - Method in class alluxio.grpc.table.LongColumnStatsData
 
hashCode() - Method in class alluxio.grpc.table.Partition
 
hashCode() - Method in class alluxio.grpc.table.PartitionSpec
 
hashCode() - Method in class alluxio.grpc.table.Range
 
hashCode() - Method in class alluxio.grpc.table.RangeSet
 
hashCode() - Method in class alluxio.grpc.table.ReadTablePRequest
 
hashCode() - Method in class alluxio.grpc.table.ReadTablePResponse
 
hashCode() - Method in class alluxio.grpc.table.Schema
 
hashCode() - Method in class alluxio.grpc.table.StringColumnStatsData
 
hashCode() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
hashCode() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
hashCode() - Method in class alluxio.grpc.table.SyncStatus
 
hashCode() - Method in class alluxio.grpc.table.TableInfo
 
hashCode() - Method in class alluxio.grpc.table.Transformation
 
hashCode() - Method in class alluxio.grpc.table.TransformJobInfo
 
hashCode() - Method in class alluxio.grpc.table.TransformTablePRequest
 
hashCode() - Method in class alluxio.grpc.table.TransformTablePResponse
 
hashCode() - Method in class alluxio.grpc.table.Value
 
hashCode() - Method in class alluxio.grpc.TierList
 
hashCode() - Method in class alluxio.grpc.TransferLeaderMessage
 
hashCode() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
hashCode() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
hashCode() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
hashCode() - Method in class alluxio.grpc.TransportMessage
 
hashCode() - Method in class alluxio.grpc.TriggerPolicyRequest
 
hashCode() - Method in class alluxio.grpc.TriggerPolicyResponse
 
hashCode() - Method in class alluxio.grpc.UfsFileStatus
 
hashCode() - Method in class alluxio.grpc.UfsInfo
 
hashCode() - Method in class alluxio.grpc.UfsReadOptions
 
hashCode() - Method in class alluxio.grpc.UfsStatus
 
hashCode() - Method in class alluxio.grpc.UnmountPOptions
 
hashCode() - Method in class alluxio.grpc.UnmountPRequest
 
hashCode() - Method in class alluxio.grpc.UnmountPResponse
 
hashCode() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
hashCode() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
hashCode() - Method in class alluxio.grpc.UpdateMountPRequest
 
hashCode() - Method in class alluxio.grpc.UpdateMountPResponse
 
hashCode() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
hashCode() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
hashCode() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
hashCode() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
hashCode() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
hashCode() - Method in class alluxio.grpc.WorkerIdentity
 
hashCode() - Method in class alluxio.grpc.WorkerInfo
 
hashCode() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
hashCode() - Method in class alluxio.grpc.WorkerNetAddress
 
hashCode() - Method in class alluxio.grpc.WriteOptions
 
hashCode() - Method in class alluxio.grpc.WriteRequest
 
hashCode() - Method in class alluxio.grpc.WriteRequestCommand
 
hashCode() - Method in class alluxio.grpc.WriteResponse
 
hashCode() - Method in class alluxio.hadoop.AlluxioFileStatus
 
hashCode() - Method in class alluxio.heartbeat.CronExpressionIntervalSupplier
 
hashCode() - Method in class alluxio.heartbeat.FixedIntervalSupplier
 
hashCode() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
hashCode() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
hashCode() - Method in class alluxio.job.JobDescription
 
hashCode() - Method in class alluxio.job.plan.BatchedJobConfig
 
hashCode() - Method in class alluxio.job.plan.meta.PlanInfo
 
hashCode() - Method in class alluxio.job.plan.migrate.MigrateCommand
 
hashCode() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
hashCode() - Method in class alluxio.job.plan.NoopPlanConfig
 
hashCode() - Method in class alluxio.job.plan.persist.PersistConfig
 
hashCode() - Method in class alluxio.job.plan.replicate.MoveConfig
 
hashCode() - Method in class alluxio.job.wire.JobServiceSummary
 
hashCode() - Method in class alluxio.job.wire.JobWorkerHealth
 
hashCode() - Method in class alluxio.job.wire.PlanInfo
 
hashCode() - Method in class alluxio.job.wire.SimpleJobStatusBlock
 
hashCode() - Method in class alluxio.job.wire.StatusSummary
 
hashCode() - Method in class alluxio.job.wire.TaskInfo
 
hashCode() - Method in class alluxio.job.wire.WorkflowInfo
 
hashCode() - Method in class alluxio.job.workflow.composite.CompositeConfig
 
hashCode() - Method in class alluxio.master.backcompat.Version
 
hashCode() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
hashCode() - Method in class alluxio.master.file.meta.Edge
 
hashCode() - Method in class alluxio.master.file.meta.Inode
 
hashCode() - Method in class alluxio.master.file.meta.MutableInode
 
hashCode() - Method in class alluxio.master.file.meta.options.MountInfo
 
hashCode() - Method in class alluxio.master.file.meta.TtlBucket
Returns the hash code for the TtlBucket.
hashCode() - Method in class alluxio.master.file.PersistJob
 
hashCode() - Method in class alluxio.master.job.CopyJob
 
hashCode() - Method in class alluxio.master.job.DoraLoadJob
 
hashCode() - Method in class alluxio.master.job.LoadJob
 
hashCode() - Method in class alluxio.master.job.MoveJob
 
hashCode() - Method in class alluxio.master.job.plan.PlanCoordinator
 
hashCode() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
hashCode() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
hashCode() - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
hashCode() - Method in interface alluxio.master.MasterInquireClient.ConnectDetails
 
hashCode() - Method in class alluxio.master.metrics.MetricsStore.ClusterCounterKey
 
hashCode() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
hashCode() - Method in class alluxio.master.predicate.interval.Interval
 
hashCode() - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoIdentity
 
hashCode() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
hashCode() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
hashCode() - Method in class alluxio.membership.WorkerServiceEntity
 
hashCode() - Method in class alluxio.metrics.Metric
 
hashCode() - Method in class alluxio.metrics.MetricKey
 
hashCode() - Method in class alluxio.metrics.MetricsFilter
 
hashCode() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
hashCode() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.Response
 
hashCode() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
hashCode() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
hashCode() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
hashCode() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
hashCode() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
hashCode() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
hashCode() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
hashCode() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
hashCode() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
hashCode() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
hashCode() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
hashCode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
hashCode() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
hashCode() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
hashCode() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
hashCode() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
hashCode() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
hashCode() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
hashCode() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
hashCode() - Method in class alluxio.proto.journal.File.RenameEntry
 
hashCode() - Method in class alluxio.proto.journal.File.SetAclEntry
 
hashCode() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
hashCode() - Method in class alluxio.proto.journal.File.StringPairEntry
 
hashCode() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
hashCode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
hashCode() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
hashCode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
hashCode() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
hashCode() - Method in class alluxio.proto.journal.Job.FileFilter
 
hashCode() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
hashCode() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
hashCode() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
hashCode() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
hashCode() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
hashCode() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
hashCode() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
hashCode() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
hashCode() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
hashCode() - Method in class alluxio.proto.meta.Block.BlockLocation
 
hashCode() - Method in class alluxio.proto.meta.Block.BlockMeta
 
hashCode() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
hashCode() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
hashCode() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
hashCode() - Method in class alluxio.proto.shared.Acl.AclActions
 
hashCode() - Method in class alluxio.proto.shared.Acl.AclEntry
 
hashCode() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
hashCode() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
hashCode() - Method in class alluxio.proxy.s3.MultipartUploadCleaner.AbortTask
 
hashCode() - Method in class alluxio.s3.ListBucketOptions
 
hashCode() - Method in class alluxio.s3.ListBucketResult.CommonPrefix
 
hashCode() - Method in class alluxio.scheduler.job.Task
 
hashCode() - Method in class alluxio.security.authorization.AccessControlList
 
hashCode() - Method in class alluxio.security.authorization.AclActions
 
hashCode() - Method in class alluxio.security.authorization.AclEntry
 
hashCode() - Method in class alluxio.security.authorization.DefaultAccessControlList
 
hashCode() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
hashCode() - Method in class alluxio.security.authorization.Mode
 
hashCode() - Method in class alluxio.security.CurrentUser
 
hashCode() - Method in class alluxio.security.user.BaseUserState
 
hashCode() - Method in class alluxio.security.User
 
hashCode() - Method in class alluxio.SessionInfo
 
hashCode() - Method in class alluxio.stress.job.StressBenchConfig
 
hashCode() - Method in class alluxio.stress.worker.IOTaskResult.Point
 
hashCode() - Method in class alluxio.underfs.AbstractUfsManager.Key
 
hashCode() - Method in class alluxio.underfs.options.CreateOptions
 
hashCode() - Method in class alluxio.underfs.options.DeleteOptions
 
hashCode() - Method in class alluxio.underfs.options.FileLocationOptions
 
hashCode() - Method in class alluxio.underfs.options.ListOptions
 
hashCode() - Method in class alluxio.underfs.options.MkdirsOptions
 
hashCode() - Method in class alluxio.underfs.options.OpenOptions
 
hashCode() - Method in class alluxio.underfs.UfsStatus
 
hashCode() - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
hashCode() - Method in class alluxio.uri.MultiMasterAuthority
 
hashCode() - Method in class alluxio.uri.MultiPartSchemeURI
 
hashCode() - Method in class alluxio.uri.NoAuthority
 
hashCode() - Method in class alluxio.uri.SingleMasterAuthority
 
hashCode() - Method in class alluxio.uri.StandardURI
 
hashCode() - Method in class alluxio.uri.UnknownAuthority
 
hashCode() - Method in class alluxio.uri.ZookeeperAuthority
 
hashCode() - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
hashCode() - Method in class alluxio.util.UnixMountInfo
 
hashCode() - Method in class alluxio.util.UnixMountInfo.Options
 
hashCode() - Method in class alluxio.util.WaitForOptions
 
hashCode() - Method in class alluxio.util.webui.NodeInfo
 
hashCode() - Method in class alluxio.wire.Address
 
hashCode() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
hashCode() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
hashCode() - Method in class alluxio.wire.AlluxioMasterInfo
 
hashCode() - Method in class alluxio.wire.AlluxioProxyInfo
 
hashCode() - Method in class alluxio.wire.AlluxioWorkerInfo
 
hashCode() - Method in class alluxio.wire.BlockInfo
 
hashCode() - Method in class alluxio.wire.BlockLocation
 
hashCode() - Method in class alluxio.wire.BlockMasterInfo
 
hashCode() - Method in class alluxio.wire.Capacity
 
hashCode() - Method in class alluxio.wire.ConfigHash
 
hashCode() - Method in class alluxio.wire.FileBlockInfo
 
hashCode() - Method in class alluxio.wire.FileInfo
 
hashCode() - Method in class alluxio.wire.InconsistentProperty
 
hashCode() - Method in class alluxio.wire.MasterInfo
 
hashCode() - Method in class alluxio.wire.MountPointInfo
 
hashCode() - Method in class alluxio.wire.WorkerIdentity
 
hashCode() - Method in class alluxio.wire.WorkerInfo
 
hashCode() - Method in class alluxio.wire.WorkerNetAddress
 
hashCode() - Method in class alluxio.worker.block.AllocateOptions
 
hashCode() - Method in class alluxio.worker.block.BlockStoreLocation
 
hashCode() - Method in class alluxio.worker.block.CreateBlockOptions
 
hasHigh() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
hasHigh() - Method in class alluxio.grpc.table.Range
optional .alluxio.grpc.table.Value high = 2;
hasHigh() - Method in interface alluxio.grpc.table.RangeOrBuilder
optional .alluxio.grpc.table.Value high = 2;
hasHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
hasHighValue() - Method in class alluxio.grpc.table.DateColumnStatsData
optional .alluxio.grpc.table.Date high_value = 2;
hasHighValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Date high_value = 2;
hasHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
hasHighValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional .alluxio.grpc.table.Decimal high_value = 2;
hasHighValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Decimal high_value = 2;
hasHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double high_value = 2;
hasHighValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional double high_value = 2;
hasHighValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional double high_value = 2;
hasHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 high_value = 2;
hasHighValue() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 high_value = 2;
hasHighValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 high_value = 2;
hashIgnoreCase(int, String) - Static method in class alluxio.util.URIUtils
Hashes a string for a URI hash, while ignoring the case.
hasHiveLayout(Partition) - Static method in class alluxio.table.ProtoUtils
 
hasHost() - Method in class alluxio.grpc.NetAddress.Builder
optional string host = 1;
hasHost() - Method in class alluxio.grpc.NetAddress
optional string host = 1;
hasHost() - Method in interface alluxio.grpc.NetAddressOrBuilder
optional string host = 1;
hasHost() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string host = 1;
hasHost() - Method in class alluxio.grpc.WorkerNetAddress
optional string host = 1;
hasHost() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional string host = 1;
hasHostname() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional string hostname = 4;
hasHostname() - Method in class alluxio.grpc.JobWorkerHealth
optional string hostname = 4;
hasHostname() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional string hostname = 4;
HashUtils - Class in alluxio.util
Util class for hashing.
hasId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
optional int64 id = 1;
hasId() - Method in interface alluxio.grpc.GetNewBlockIdForFilePResponseOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.JobInfo
optional int64 id = 1;
hasId() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.PolicyInfo
optional int64 id = 1;
hasId() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
optional int64 id = 1;
hasId() - Method in interface alluxio.grpc.RegisterJobWorkerPResponseOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional uint32 id = 1;
hasId() - Method in class alluxio.grpc.table.FieldSchema
optional uint32 id = 1;
hasId() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional uint32 id = 1;
hasId() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.WorkerInfo
optional int64 id = 1;
hasId() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.grpc.WriteRequestCommand.Builder
The block ID or UFS file ID.
hasId() - Method in class alluxio.grpc.WriteRequestCommand
The block ID or UFS file ID.
hasId() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
The block ID or UFS file ID.
hasId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
The block ID or UFS file ID.
hasId() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
The block ID or UFS file ID.
hasId() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
The block ID or UFS file ID.
hasId() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 id = 2;
hasId() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 id = 2;
hasId() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 id = 2;
hasId() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.NewBlockEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.NewBlockEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.PersistDirectoryEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.SetAclEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 id = 1;
hasId() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 id = 1;
hasId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 id = 1;
hasIdentifier() - Method in class alluxio.grpc.WorkerIdentity.Builder
exactly how this byte sequence is interpreted depends on the version of its definition
hasIdentifier() - Method in class alluxio.grpc.WorkerIdentity
exactly how this byte sequence is interpreted depends on the version of its definition
hasIdentifier() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
exactly how this byte sequence is interpreted depends on the version of its definition
hasIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignoreClusterConf = 2;
hasIgnoreClusterConf() - Method in class alluxio.grpc.GetConfigurationPOptions
optional bool ignoreClusterConf = 2;
hasIgnoreClusterConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
optional bool ignoreClusterConf = 2;
hasIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignorePathConf = 3;
hasIgnorePathConf() - Method in class alluxio.grpc.GetConfigurationPOptions
optional bool ignorePathConf = 3;
hasIgnorePathConf() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
optional bool ignorePathConf = 3;
hasIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional bool ignore_sync_errors = 6;
hasIgnoreSyncErrors() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional bool ignore_sync_errors = 6;
hasIgnoreSyncErrors() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional bool ignore_sync_errors = 6;
hasInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inAlluxioPercentage = 24;
hasInAlluxioPercentage() - Method in class alluxio.grpc.FileInfo
optional int32 inAlluxioPercentage = 24;
hasInAlluxioPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 inAlluxioPercentage = 24;
hasIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool includeRealContentHash = 5;
hasIncludeRealContentHash() - Method in class alluxio.grpc.GetStatusPOptions
optional bool includeRealContentHash = 5;
hasIncludeRealContentHash() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional bool includeRealContentHash = 5;
hasInMemoryPercentage() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inMemoryPercentage = 25;
hasInMemoryPercentage() - Method in class alluxio.grpc.FileInfo
optional int32 inMemoryPercentage = 25;
hasInMemoryPercentage() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 inMemoryPercentage = 25;
hasInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
hasInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
hasInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
hasInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
hasInodeDirectoryIdGenerator() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
hasInodeDirectoryIdGenerator() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
hasInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
hasInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
hasInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
hasInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
hasInodeLastModificationTime() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
hasInodeLastModificationTime() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
hasInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string input_format = 2;
hasInputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string input_format = 2;
hasInputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string input_format = 2;
hasInstance() - Method in class alluxio.grpc.Metric.Builder
optional string instance = 1;
hasInstance() - Method in class alluxio.grpc.Metric
optional string instance = 1;
hasInstance() - Method in interface alluxio.grpc.MetricOrBuilder
optional string instance = 1;
hasIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool isAtomicWrite = 16;
hasIsAtomicWrite() - Method in class alluxio.grpc.CreateFilePOptions
optional bool isAtomicWrite = 16;
hasIsAtomicWrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool isAtomicWrite = 16;
hasIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_cacheable = 17;
hasIsCacheable() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_cacheable = 17;
hasIsCacheable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_cacheable = 17;
hasIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_completed = 18;
hasIsCompleted() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_completed = 18;
hasIsCompleted() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_completed = 18;
hasIsDefault() - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefault = 5;
hasIsDefault() - Method in class alluxio.grpc.PAcl
optional bool isDefault = 5;
hasIsDefault() - Method in class alluxio.grpc.PAclEntry.Builder
optional bool isDefault = 4;
hasIsDefault() - Method in class alluxio.grpc.PAclEntry
optional bool isDefault = 4;
hasIsDefault() - Method in interface alluxio.grpc.PAclEntryOrBuilder
optional bool isDefault = 4;
hasIsDefault() - Method in interface alluxio.grpc.PAclOrBuilder
optional bool isDefault = 5;
hasIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isDefault = 7;
hasIsDefault() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional bool isDefault = 7;
hasIsDefault() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional bool isDefault = 7;
hasIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional bool isDefault = 4;
hasIsDefault() - Method in class alluxio.proto.shared.Acl.AclEntry
optional bool isDefault = 4;
hasIsDefault() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
optional bool isDefault = 4;
hasIsDefaultEmpty() - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefaultEmpty = 6;
hasIsDefaultEmpty() - Method in class alluxio.grpc.PAcl
optional bool isDefaultEmpty = 6;
hasIsDefaultEmpty() - Method in interface alluxio.grpc.PAclOrBuilder
optional bool isDefaultEmpty = 6;
hasIsDirectory() - Method in class alluxio.grpc.UfsStatus.Builder
optional bool is_directory = 2;
hasIsDirectory() - Method in class alluxio.grpc.UfsStatus
optional bool is_directory = 2;
hasIsDirectory() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional bool is_directory = 2;
hasIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_directory = 3;
hasIsDirectory() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_directory = 3;
hasIsDirectory() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_directory = 3;
hasIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isEmpty = 8;
hasIsEmpty() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional bool isEmpty = 8;
hasIsEmpty() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional bool isEmpty = 8;
hasIsLeader() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional bool isLeader = 3;
hasIsLeader() - Method in class alluxio.grpc.QuorumServerInfo
optional bool isLeader = 3;
hasIsLeader() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional bool isLeader = 3;
hasIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
directory only
hasIsMountPoint() - Method in class alluxio.proto.meta.InodeMeta.Inode
directory only
hasIsMountPoint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
directory only
hasIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool isMultipartUpload = 2;
hasIsMultipartUpload() - Method in class alluxio.grpc.S3SyntaxOptions
optional bool isMultipartUpload = 2;
hasIsMultipartUpload() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
optional bool isMultipartUpload = 2;
hasIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_pinned = 9;
hasIsPinned() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional bool is_pinned = 9;
hasIsPinned() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional bool is_pinned = 9;
hasIsRetryable() - Method in class alluxio.grpc.RetryInfo.Builder
optional bool isRetryable = 1;
hasIsRetryable() - Method in class alluxio.grpc.RetryInfo
optional bool isRetryable = 1;
hasIsRetryable() - Method in interface alluxio.grpc.RetryInfoOrBuilder
optional bool isRetryable = 1;
hasIsScanning() - Method in class alluxio.grpc.PolicyStatus.Builder
optional bool isScanning = 11;
hasIsScanning() - Method in class alluxio.grpc.PolicyStatus
optional bool isScanning = 11;
hasIsScanning() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional bool isScanning = 11;
hasIsSkip() - Method in class alluxio.grpc.RouteFailure.Builder
optional bool is_skip = 5;
hasIsSkip() - Method in class alluxio.grpc.RouteFailure
optional bool is_skip = 5;
hasIsSkip() - Method in interface alluxio.grpc.RouteFailureOrBuilder
optional bool is_skip = 5;
hasIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional bool isThrowable = 2;
hasIsThrowable() - Method in class alluxio.grpc.MessagingResponseHeader
optional bool isThrowable = 2;
hasIsThrowable() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
optional bool isThrowable = 2;
hasIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
True if the partial listing was truncated.
hasIsTruncated() - Method in class alluxio.grpc.ListStatusPartialPResponse
True if the partial listing was truncated.
hasIsTruncated() - Method in interface alluxio.grpc.ListStatusPartialPResponseOrBuilder
True if the partial listing was truncated.
hasJobConfig() - Method in class alluxio.grpc.RunPRequest.Builder
optional bytes jobConfig = 1;
hasJobConfig() - Method in class alluxio.grpc.RunPRequest
optional bytes jobConfig = 1;
hasJobConfig() - Method in interface alluxio.grpc.RunPRequestOrBuilder
optional bytes jobConfig = 1;
hasJobConfig() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes jobConfig = 3;
hasJobConfig() - Method in class alluxio.grpc.RunTaskCommand
optional bytes jobConfig = 3;
hasJobConfig() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional bytes jobConfig = 3;
hasJobControlId() - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.CmdStatusBlock
optional int64 jobControlId = 1;
hasJobControlId() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.CmdSummary
optional int64 jobControlId = 1;
hasJobControlId() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
optional int64 jobControlId = 1;
hasJobControlId() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.GetCmdStatusRequest
optional int64 jobControlId = 1;
hasJobControlId() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.SubmitResponse.Builder
optional int64 jobControlId = 1;
hasJobControlId() - Method in class alluxio.grpc.SubmitResponse
optional int64 jobControlId = 1;
hasJobControlId() - Method in interface alluxio.grpc.SubmitResponseOrBuilder
optional int64 jobControlId = 1;
hasJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
hasJobDescription() - Method in class alluxio.grpc.GetJobProgressPRequest
required .alluxio.grpc.file.JobDescription jobDescription = 1;
hasJobDescription() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
hasJobDescription() - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
hasJobDescription() - Method in class alluxio.grpc.StopJobPRequest
required .alluxio.grpc.file.JobDescription jobDescription = 1;
hasJobDescription() - Method in interface alluxio.grpc.StopJobPRequestOrBuilder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
hasJobError() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string job_error = 6;
hasJobError() - Method in class alluxio.grpc.table.TransformJobInfo
optional string job_error = 6;
hasJobError() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string job_error = 6;
hasJobId() - Method in class alluxio.grpc.CancelPRequest.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.CancelPRequest
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.CancelTaskCommand
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.GetJobStatusPRequest
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.JobProgress
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.JobStatusBlock
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.RunPResponse.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.RunPResponse
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.RunPResponseOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.RunTaskCommand
optional int64 jobId = 1;
hasJobId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional int64 jobId = 1;
hasJobId() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
optional string jobId = 1;
hasJobId() - Method in class alluxio.grpc.SubmitJobPResponse
optional string jobId = 1;
hasJobId() - Method in interface alluxio.grpc.SubmitJobPResponseOrBuilder
optional string jobId = 1;
hasJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
optional int64 job_id = 1;
hasJobId() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
optional int64 job_id = 1;
hasJobId() - Method in interface alluxio.grpc.table.GetTransformJobInfoPRequestOrBuilder
optional int64 job_id = 1;
hasJobId() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional int64 job_id = 4;
hasJobId() - Method in class alluxio.grpc.table.TransformJobInfo
optional int64 job_id = 4;
hasJobId() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional int64 job_id = 4;
hasJobId() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
optional int64 job_id = 1;
hasJobId() - Method in class alluxio.grpc.table.TransformTablePResponse
optional int64 job_id = 1;
hasJobId() - Method in interface alluxio.grpc.table.TransformTablePResponseOrBuilder
optional int64 job_id = 1;
hasJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string job_id = 8;
hasJobId() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string job_id = 8;
hasJobId() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string job_id = 8;
hasJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string job_id = 7;
hasJobId() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required string job_id = 7;
hasJobId() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required string job_id = 7;
hasJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string job_id = 8;
hasJobId() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string job_id = 8;
hasJobId() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string job_id = 8;
hasJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions.Builder
optional bool jobIdOnly = 3;
hasJobIdOnly() - Method in class alluxio.grpc.ListAllPOptions
optional bool jobIdOnly = 3;
hasJobIdOnly() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
optional bool jobIdOnly = 3;
hasJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
hasJobInfo() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
hasJobInfo() - Method in interface alluxio.grpc.GetJobStatusDetailedPResponseOrBuilder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
hasJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
hasJobInfo() - Method in class alluxio.grpc.GetJobStatusPResponse
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
hasJobInfo() - Method in interface alluxio.grpc.GetJobStatusPResponseOrBuilder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
hasJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional int64 jobMasterId = 1;
hasJobMasterId() - Method in class alluxio.grpc.RegisterJobMasterPRequest
optional int64 jobMasterId = 1;
hasJobMasterId() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
optional int64 jobMasterId = 1;
hasJobSource() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.JobSource jobSource = 3;
hasJobSource() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.JobSource jobSource = 3;
hasJobSource() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.JobSource jobSource = 3;
hasJobStatus() - Method in class alluxio.grpc.JobStatusBlock.Builder
optional .alluxio.grpc.job.Status jobStatus = 2;
hasJobStatus() - Method in class alluxio.grpc.JobStatusBlock
optional .alluxio.grpc.job.Status jobStatus = 2;
hasJobStatus() - Method in interface alluxio.grpc.JobStatusBlockOrBuilder
optional .alluxio.grpc.job.Status jobStatus = 2;
hasJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional .alluxio.grpc.job.Status job_status = 5;
hasJobStatus() - Method in class alluxio.grpc.table.TransformJobInfo
optional .alluxio.grpc.job.Status job_status = 5;
hasJobStatus() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional .alluxio.grpc.job.Status job_status = 5;
hasJobStopped() - Method in class alluxio.grpc.StopJobPResponse.Builder
optional bool jobStopped = 1;
hasJobStopped() - Method in class alluxio.grpc.StopJobPResponse
optional bool jobStopped = 1;
hasJobStopped() - Method in interface alluxio.grpc.StopJobPResponseOrBuilder
optional bool jobStopped = 1;
hasJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
hasJobWorkerHealth() - Method in class alluxio.grpc.JobHeartbeatPRequest
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
hasJobWorkerHealth() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
hasJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 journalEntriesSinceCheckpoint = 2;
hasJournalEntriesSinceCheckpoint() - Method in class alluxio.grpc.MasterHeartbeatPOptions
optional int64 journalEntriesSinceCheckpoint = 2;
hasJournalEntriesSinceCheckpoint() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
optional int64 journalEntriesSinceCheckpoint = 2;
hasKey() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
hasKey() - Method in class alluxio.grpc.LocationBlockIdListEntry
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
hasKey() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
hasKey() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
hasKey() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string key = 1;
hasKey() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string key = 1;
hasLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_accessed_ms = 30;
hasLastAccessedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 last_accessed_ms = 30;
hasLastAccessedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 last_accessed_ms = 30;
hasLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastAccessTimeMs = 31;
hasLastAccessTimeMs() - Method in class alluxio.grpc.FileInfo
optional int64 lastAccessTimeMs = 31;
hasLastAccessTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 lastAccessTimeMs = 31;
hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_access_time_ms = 20;
hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 last_access_time_ms = 20;
hasLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 last_access_time_ms = 20;
hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_access_time_ms = 29;
hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 last_access_time_ms = 29;
hasLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 last_access_time_ms = 29;
hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_access_time_ms = 18;
hasLastAccessTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 last_access_time_ms = 18;
hasLastAccessTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 last_access_time_ms = 18;
hasLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 lastCheckpointTime = 1;
hasLastCheckpointTime() - Method in class alluxio.grpc.MasterHeartbeatPOptions
optional int64 lastCheckpointTime = 1;
hasLastCheckpointTime() - Method in interface alluxio.grpc.MasterHeartbeatPOptionsOrBuilder
optional int64 lastCheckpointTime = 1;
hasLastContactSec() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int32 lastContactSec = 3;
hasLastContactSec() - Method in class alluxio.grpc.WorkerInfo
optional int32 lastContactSec = 3;
hasLastContactSec() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int32 lastContactSec = 3;
hasLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 lastHeartbeatTime = 4;
hasLastHeartbeatTime() - Method in class alluxio.grpc.ProxyStatus
optional int64 lastHeartbeatTime = 4;
hasLastHeartbeatTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional int64 lastHeartbeatTime = 4;
hasLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastModificationTimeMs = 14;
hasLastModificationTimeMs() - Method in class alluxio.grpc.FileInfo
optional int64 lastModificationTimeMs = 14;
hasLastModificationTimeMs() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 lastModificationTimeMs = 14;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 last_modification_time_ms = 2;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
optional int64 last_modification_time_ms = 2;
hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.InodeLastModificationTimeEntryOrBuilder
optional int64 last_modification_time_ms = 2;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 last_modification_time_ms = 7;
hasLastModificationTimeMs() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 last_modification_time_ms = 7;
hasLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_modified_ms = 25;
hasLastModifiedMs() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 last_modified_ms = 25;
hasLastModifiedMs() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 last_modified_ms = 25;
hasLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus.Builder
optional int64 last_modified_time_ms = 3;
hasLastModifiedTimeMs() - Method in class alluxio.grpc.UfsStatus
optional int64 last_modified_time_ms = 3;
hasLastModifiedTimeMs() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional int64 last_modified_time_ms = 3;
hasLastUpdated() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 lastUpdated = 6;
hasLastUpdated() - Method in class alluxio.grpc.JobInfo
optional int64 lastUpdated = 6;
hasLastUpdated() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional int64 lastUpdated = 6;
hasLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 lastUpdated = 3;
hasLastUpdated() - Method in class alluxio.grpc.JobWorkerHealth
optional int64 lastUpdated = 3;
hasLastUpdated() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int64 lastUpdated = 3;
hasLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo.Builder
optional int64 lastUpdatedTime = 5;
hasLastUpdatedTime() - Method in class alluxio.grpc.ActionInfo
optional int64 lastUpdatedTime = 5;
hasLastUpdatedTime() - Method in interface alluxio.grpc.ActionInfoOrBuilder
optional int64 lastUpdatedTime = 5;
hasLastUpdateMs() - Method in class alluxio.grpc.JobProgress.Builder
optional int64 lastUpdateMs = 4;
hasLastUpdateMs() - Method in class alluxio.grpc.JobProgress
optional int64 lastUpdateMs = 4;
hasLastUpdateMs() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional int64 lastUpdateMs = 4;
hasLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated. 
hasLatest() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated. 
hasLatest() - Method in interface alluxio.grpc.GetSnapshotInfoResponseOrBuilder
Deprecated. 
hasLayout() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
hasLayout() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.Layout layout = 6;
hasLayout() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.Layout layout = 6;
hasLayout() - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
hasLayout() - Method in class alluxio.grpc.table.Transformation
optional .alluxio.grpc.table.Layout layout = 1;
hasLayout() - Method in interface alluxio.grpc.table.TransformationOrBuilder
optional .alluxio.grpc.table.Layout layout = 1;
hasLayoutData() - Method in class alluxio.grpc.table.Layout.Builder
optional bytes layout_data = 3;
hasLayoutData() - Method in class alluxio.grpc.table.Layout
optional bytes layout_data = 3;
hasLayoutData() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional bytes layout_data = 3;
hasLayoutSpec() - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
hasLayoutSpec() - Method in class alluxio.grpc.table.Layout
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
hasLayoutSpec() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
hasLayoutType() - Method in class alluxio.grpc.table.Layout.Builder
optional string layout_type = 1;
hasLayoutType() - Method in class alluxio.grpc.table.Layout
optional string layout_type = 1;
hasLayoutType() - Method in interface alluxio.grpc.table.LayoutOrBuilder
optional string layout_type = 1;
hasLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo.Builder
optional string leaderMasterAddress = 1;
hasLeaderMasterAddress() - Method in class alluxio.grpc.MasterInfo
optional string leaderMasterAddress = 1;
hasLeaderMasterAddress() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string leaderMasterAddress = 1;
hasLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 leastSignificantBits = 2;
hasLeastSignificantBits() - Method in class alluxio.grpc.FsOpPId
optional int64 leastSignificantBits = 2;
hasLeastSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
optional int64 leastSignificantBits = 2;
hasLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 leastSignificantBits = 2;
hasLeastSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
optional int64 leastSignificantBits = 2;
hasLeastSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
optional int64 leastSignificantBits = 2;
hasLength() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 length = 5;
hasLength() - Method in class alluxio.grpc.AsyncCacheRequest
optional int64 length = 5;
hasLength() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional int64 length = 5;
hasLength() - Method in class alluxio.grpc.Block.Builder
The block length.
hasLength() - Method in class alluxio.grpc.Block
The block length.
hasLength() - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 length = 2;
hasLength() - Method in class alluxio.grpc.BlockInfo
optional int64 length = 2;
hasLength() - Method in interface alluxio.grpc.BlockInfoOrBuilder
optional int64 length = 2;
hasLength() - Method in interface alluxio.grpc.BlockOrBuilder
The block length.
hasLength() - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 length = 5;
hasLength() - Method in class alluxio.grpc.CacheRequest
optional int64 length = 5;
hasLength() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional int64 length = 5;
hasLength() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the length of the block being committed
hasLength() - Method in class alluxio.grpc.CommitBlockPRequest
the length of the block being committed
hasLength() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the length of the block being committed
hasLength() - Method in class alluxio.grpc.File.Builder
file length
hasLength() - Method in class alluxio.grpc.File
file length
hasLength() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 length = 5;
hasLength() - Method in class alluxio.grpc.FileInfo
optional int64 length = 5;
hasLength() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 length = 5;
hasLength() - Method in interface alluxio.grpc.FileOrBuilder
file length
hasLength() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 length = 3;
hasLength() - Method in class alluxio.grpc.ReadRequest
optional int64 length = 3;
hasLength() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 length = 3;
hasLength() - Method in class alluxio.grpc.Route.Builder
optional int64 length = 3;
hasLength() - Method in class alluxio.grpc.Route
optional int64 length = 3;
hasLength() - Method in interface alluxio.grpc.RouteOrBuilder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int64 length = 5;
hasLength() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int64 length = 5;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 length = 3;
hasLength() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
hasLength() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
optional int64 length = 2;
hasLength() - Method in interface alluxio.proto.journal.Block.BlockInfoEntryOrBuilder
optional int64 length = 2;
hasLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 length = 3;
hasLength() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
hasLength() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 length = 9;
hasLength() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 length = 9;
hasLength() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
hasLength() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 length = 2;
hasLength() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 length = 2;
hasLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 length = 3;
hasLength() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 length = 3;
hasLength() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
optional int64 length = 1;
hasLength() - Method in class alluxio.proto.meta.Block.BlockMeta
optional int64 length = 1;
hasLength() - Method in interface alluxio.proto.meta.Block.BlockMetaOrBuilder
optional int64 length = 1;
hasLength() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 length = 19;
hasLength() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 length = 19;
hasLength() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 length = 19;
hasLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 liveWorkerNum = 4;
hasLiveWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
optional int32 liveWorkerNum = 4;
hasLiveWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int32 liveWorkerNum = 4;
hasLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
hasLoadDescendantType() - Method in class alluxio.grpc.LoadMetadataPOptions
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
hasLoadDescendantType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
hasLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions.Builder
This is deprecated since 1.1.1 and will be removed in 2.0.
hasLoadDirectChildren() - Method in class alluxio.grpc.ListStatusPOptions
This is deprecated since 1.1.1 and will be removed in 2.0.
hasLoadDirectChildren() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
This is deprecated since 1.1.1 and will be removed in 2.0.
hasLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
hasLoadJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
hasLoadJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
hasLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions.Builder
No data will be transferred.
hasLoadMetadataOnly() - Method in class alluxio.grpc.ListStatusPOptions
No data will be transferred.
hasLoadMetadataOnly() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
No data will be transferred.
hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest.Builder
If set false, only the metadata of file will be loaded.
hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadFileRequest
If set false, only the metadata of file will be loaded.
hasLoadMetadataOnly() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
If set false, only the metadata of file will be loaded.
hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool loadMetadataOnly = 4;
hasLoadMetadataOnly() - Method in class alluxio.grpc.LoadJobPOptions
optional bool loadMetadataOnly = 4;
hasLoadMetadataOnly() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool loadMetadataOnly = 4;
hasLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool load_metadata_only = 9;
hasLoadMetadataOnly() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional bool load_metadata_only = 9;
hasLoadMetadataOnly() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional bool load_metadata_only = 9;
hasLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
hasLoadMetadataType() - Method in class alluxio.grpc.ExistsPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
hasLoadMetadataType() - Method in interface alluxio.grpc.ExistsPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
hasLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
hasLoadMetadataType() - Method in class alluxio.grpc.GetStatusPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
hasLoadMetadataType() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
hasLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
hasLoadMetadataType() - Method in class alluxio.grpc.ListStatusPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
hasLoadMetadataType() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
hasLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string load_path = 1;
hasLoadPath() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required string load_path = 1;
hasLoadPath() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required string load_path = 1;
hasLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
hasLoadType() - Method in class alluxio.grpc.LoadMetadataPOptions
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
hasLoadType() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
hasLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool localFileSystem = 1;
hasLocalFileSystem() - Method in class alluxio.grpc.BackupPOptions
optional bool localFileSystem = 1;
hasLocalFileSystem() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool localFileSystem = 1;
hasLocation() - Method in class alluxio.grpc.table.Database.Builder
optional string location = 3;
hasLocation() - Method in class alluxio.grpc.table.Database
optional string location = 3;
hasLocation() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string location = 3;
hasLocation() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional string location = 2;
hasLocation() - Method in class alluxio.grpc.table.layout.hive.Storage
optional string location = 2;
hasLocation() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional string location = 2;
hasLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
hasLongStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
hasLongStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
hasLongType() - Method in class alluxio.grpc.table.Value.Builder
int64 long_type = 1;
hasLongType() - Method in class alluxio.grpc.table.Value
int64 long_type = 1;
hasLongType() - Method in interface alluxio.grpc.table.ValueOrBuilder
int64 long_type = 1;
hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
optional int64 losePrimacyTimeMs = 3;
hasLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
optional int64 losePrimacyTimeMs = 3;
hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
hasLosePrimacyTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
optional int64 losePrimacyTimeMs = 3;
hasLosePrimacyTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional int64 losePrimacyTimeMs = 3;
hasLostStorage() - Method in class alluxio.master.block.meta.MasterWorkerInfo
hasLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 lostWorkerNum = 5;
hasLostWorkerNum() - Method in class alluxio.grpc.BlockMasterInfo
optional int32 lostWorkerNum = 5;
hasLostWorkerNum() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int32 lostWorkerNum = 5;
hasLow() - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
hasLow() - Method in class alluxio.grpc.table.Range
optional .alluxio.grpc.table.Value low = 1;
hasLow() - Method in interface alluxio.grpc.table.RangeOrBuilder
optional .alluxio.grpc.table.Value low = 1;
hasLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
hasLowValue() - Method in class alluxio.grpc.table.DateColumnStatsData
optional .alluxio.grpc.table.Date low_value = 1;
hasLowValue() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Date low_value = 1;
hasLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
hasLowValue() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional .alluxio.grpc.table.Decimal low_value = 1;
hasLowValue() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional .alluxio.grpc.table.Decimal low_value = 1;
hasLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double low_value = 1;
hasLowValue() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional double low_value = 1;
hasLowValue() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional double low_value = 1;
hasLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 low_value = 1;
hasLowValue() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 low_value = 1;
hasLowValue() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 low_value = 1;
hasMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
hasMaskActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional .alluxio.proto.shared.AclActions maskActions = 5;
hasMaskActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional .alluxio.proto.shared.AclActions maskActions = 5;
hasMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
hasMasterAddress() - Method in class alluxio.grpc.GetJobMasterIdPRequest
optional .alluxio.grpc.NetAddress masterAddress = 1;
hasMasterAddress() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 1;
hasMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
hasMasterAddress() - Method in class alluxio.grpc.GetMasterIdPRequest
optional .alluxio.grpc.NetAddress masterAddress = 1;
hasMasterAddress() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 1;
hasMasterAddress() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
hasMasterAddress() - Method in class alluxio.grpc.JobMasterStatus
optional .alluxio.grpc.NetAddress masterAddress = 2;
hasMasterAddress() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional .alluxio.grpc.NetAddress masterAddress = 2;
hasMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse.Builder
The hostname of the master that did the checkpoint
hasMasterHostname() - Method in class alluxio.grpc.CheckpointPResponse
The hostname of the master that did the checkpoint
hasMasterHostname() - Method in interface alluxio.grpc.CheckpointPResponseOrBuilder
The hostname of the master that did the checkpoint
hasMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.GetJobMasterIdPResponse
optional int64 masterId = 1;
hasMasterId() - Method in interface alluxio.grpc.GetJobMasterIdPResponseOrBuilder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.GetMasterIdPResponse
optional int64 masterId = 1;
hasMasterId() - Method in interface alluxio.grpc.GetMasterIdPResponseOrBuilder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
optional int64 masterId = 1;
hasMasterId() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.MasterHeartbeatPRequest
optional int64 masterId = 1;
hasMasterId() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional int64 masterId = 1;
hasMasterId() - Method in class alluxio.grpc.RegisterMasterPRequest
optional int64 masterId = 1;
hasMasterId() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
optional int64 masterId = 1;
hasMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
hasMasterInfo() - Method in class alluxio.grpc.GetMasterInfoPResponse
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
hasMasterInfo() - Method in interface alluxio.grpc.GetMasterInfoPResponseOrBuilder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
hasMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 max_col_len = 1;
hasMaxColLen() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional int64 max_col_len = 1;
hasMaxColLen() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional int64 max_col_len = 1;
hasMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 max_col_len = 1;
hasMaxColLen() - Method in class alluxio.grpc.table.StringColumnStatsData
optional int64 max_col_len = 1;
hasMaxColLen() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional int64 max_col_len = 1;
hasMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional int32 maxUfsReadConcurrency = 2;
hasMaxUfsReadConcurrency() - Method in class alluxio.grpc.OpenFilePOptions
optional int32 maxUfsReadConcurrency = 2;
hasMaxUfsReadConcurrency() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional int32 maxUfsReadConcurrency = 2;
hasMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
hasMaxUfsReadConcurrency() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int32 maxUfsReadConcurrency = 4;
hasMaxUfsReadConcurrency() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int32 maxUfsReadConcurrency = 4;
hasMediumType() - Method in class alluxio.grpc.BlockLocation.Builder
optional string mediumType = 4;
hasMediumType() - Method in class alluxio.grpc.BlockLocation
optional string mediumType = 4;
hasMediumType() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional string mediumType = 4;
hasMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string mediumType = 2;
hasMediumType() - Method in class alluxio.grpc.BlockStoreLocationProto
optional string mediumType = 2;
hasMediumType() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
optional string mediumType = 2;
hasMediumType() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional string mediumType = 7;
hasMediumType() - Method in class alluxio.grpc.CommitBlockPRequest
optional string mediumType = 7;
hasMediumType() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
optional string mediumType = 7;
hasMediumType() - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional string medium_type = 2;
hasMediumType() - Method in class alluxio.grpc.MoveBlockRequest
optional string medium_type = 2;
hasMediumType() - Method in interface alluxio.grpc.MoveBlockRequestOrBuilder
optional string medium_type = 2;
hasMediumType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional string medium_type = 8;
hasMediumType() - Method in class alluxio.grpc.WriteRequestCommand
optional string medium_type = 8;
hasMediumType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional string medium_type = 8;
hasMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string mediumType = 3;
hasMediumType() - Method in class alluxio.proto.meta.Block.BlockLocation
optional string mediumType = 3;
hasMediumType() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional string mediumType = 3;
hasMessage() - Method in class alluxio.grpc.BlockStatus.Builder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.BlockStatus
A developer-facing error message
hasMessage() - Method in interface alluxio.grpc.BlockStatusOrBuilder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.FileFailure.Builder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.FileFailure
A developer-facing error message
hasMessage() - Method in interface alluxio.grpc.FileFailureOrBuilder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.LoadFileFailure.Builder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.LoadFileFailure
A developer-facing error message
hasMessage() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.RouteFailure.Builder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.RouteFailure
A developer-facing error message
hasMessage() - Method in interface alluxio.grpc.RouteFailureOrBuilder
A developer-facing error message
hasMessage() - Method in class alluxio.grpc.SaslMessage.Builder
optional bytes message = 2;
hasMessage() - Method in class alluxio.grpc.SaslMessage
optional bytes message = 2;
hasMessage() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional bytes message = 2;
hasMessage() - Method in class alluxio.grpc.TransportMessage.Builder
optional bytes message = 3;
hasMessage() - Method in class alluxio.grpc.TransportMessage
optional bytes message = 3;
hasMessage() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional bytes message = 3;
hasMessage() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
hasMessage() - Method in class alluxio.proto.dataserver.Protocol.Response
optional string message = 2;
hasMessage() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional string message = 2;
hasMessageType() - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
hasMessageType() - Method in class alluxio.grpc.SaslMessage
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
hasMessageType() - Method in interface alluxio.grpc.SaslMessageOrBuilder
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
hasMetricType() - Method in class alluxio.grpc.Metric.Builder
required .alluxio.grpc.MetricType metricType = 5;
hasMetricType() - Method in class alluxio.grpc.Metric
required .alluxio.grpc.MetricType metricType = 5;
hasMetricType() - Method in interface alluxio.grpc.MetricOrBuilder
required .alluxio.grpc.MetricType metricType = 5;
hasMetricType() - Method in class alluxio.grpc.MetricValue.Builder
optional .alluxio.grpc.MetricType metricType = 6;
hasMetricType() - Method in class alluxio.grpc.MetricValue
optional .alluxio.grpc.MetricType metricType = 6;
hasMetricType() - Method in interface alluxio.grpc.MetricValueOrBuilder
optional .alluxio.grpc.MetricType metricType = 6;
hasMode() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
hasMode() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.PMode mode = 3;
hasMode() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 3;
hasMode() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
hasMode() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.PMode mode = 3;
hasMode() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 3;
hasMode() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 mode = 18;
hasMode() - Method in class alluxio.grpc.FileInfo
optional int32 mode = 18;
hasMode() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 mode = 18;
hasMode() - Method in class alluxio.grpc.PAcl.Builder
optional int32 mode = 4;
hasMode() - Method in class alluxio.grpc.PAcl
optional int32 mode = 4;
hasMode() - Method in interface alluxio.grpc.PAclOrBuilder
optional int32 mode = 4;
hasMode() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
hasMode() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.grpc.PMode mode = 5;
hasMode() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.grpc.PMode mode = 5;
hasMode() - Method in class alluxio.grpc.UfsStatus.Builder
optional int32 mode = 6;
hasMode() - Method in class alluxio.grpc.UfsStatus
optional int32 mode = 6;
hasMode() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional int32 mode = 6;
hasMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int32 mode = 4;
hasMode() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int32 mode = 4;
hasMode() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int32 mode = 4;
hasMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int32 mode = 10;
hasMode() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int32 mode = 10;
hasMode() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int32 mode = 10;
hasMode() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 mode = 16;
hasMode() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 mode = 16;
hasMode() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 mode = 16;
hasMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int32 mode = 11;
hasMode() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int32 mode = 11;
hasMode() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int32 mode = 11;
hasMostSignificantBits() - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 mostSignificantBits = 1;
hasMostSignificantBits() - Method in class alluxio.grpc.FsOpPId
optional int64 mostSignificantBits = 1;
hasMostSignificantBits() - Method in interface alluxio.grpc.FsOpPIdOrBuilder
optional int64 mostSignificantBits = 1;
hasMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 mostSignificantBits = 1;
hasMostSignificantBits() - Method in class alluxio.proto.journal.Journal.JournalOpPId
optional int64 mostSignificantBits = 1;
hasMostSignificantBits() - Method in interface alluxio.proto.journal.Journal.JournalOpPIdOrBuilder
optional int64 mostSignificantBits = 1;
hasMount(long) - Method in class alluxio.underfs.AbstractUfsManager
 
hasMount(long) - Method in class alluxio.underfs.MasterUfsManager
 
hasMount(long) - Method in interface alluxio.underfs.UfsManager
Checks if a mountId exists.
hasMountId() - Method in class alluxio.grpc.Block.Builder
optional int64 mountId = 5;
hasMountId() - Method in class alluxio.grpc.Block
optional int64 mountId = 5;
hasMountId() - Method in interface alluxio.grpc.BlockOrBuilder
optional int64 mountId = 5;
hasMountId() - Method in class alluxio.grpc.File.Builder
optional int64 mountId = 4;
hasMountId() - Method in class alluxio.grpc.File
optional int64 mountId = 4;
hasMountId() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 mountId = 23;
hasMountId() - Method in class alluxio.grpc.FileInfo
optional int64 mountId = 23;
hasMountId() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 mountId = 23;
hasMountId() - Method in interface alluxio.grpc.FileOrBuilder
optional int64 mountId = 4;
hasMountId() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
required int64 mountId = 1;
hasMountId() - Method in class alluxio.grpc.GetMountIdPResponse
required int64 mountId = 1;
hasMountId() - Method in interface alluxio.grpc.GetMountIdPResponseOrBuilder
required int64 mountId = 1;
hasMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
the id of the ufs
hasMountId() - Method in class alluxio.grpc.GetUfsInfoPRequest
the id of the ufs
hasMountId() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
the id of the ufs
hasMountId() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 mountId = 8;
hasMountId() - Method in class alluxio.grpc.MountPointInfo
optional int64 mountId = 8;
hasMountId() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional int64 mountId = 8;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int64 mount_id = 5;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional int64 mount_id = 5;
hasMountId() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional int64 mount_id = 5;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 mountId = 5;
hasMountId() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional int64 mountId = 5;
hasMountId() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional int64 mountId = 5;
hasMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 mount_id = 1;
hasMountId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
optional int64 mount_id = 1;
hasMountId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
optional int64 mount_id = 1;
hasMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional int64 mount_id = 6;
hasMountId() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional int64 mount_id = 6;
hasMountId() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional int64 mount_id = 6;
hasMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional int64 mount_id = 2;
hasMountId() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
optional int64 mount_id = 2;
hasMountId() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
optional int64 mount_id = 2;
hasMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional int64 mount_id = 2;
hasMountId() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
optional int64 mount_id = 2;
hasMountId() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
optional int64 mount_id = 2;
hasMountPoint() - Method in class alluxio.grpc.FileInfo.Builder
optional bool mountPoint = 20;
hasMountPoint() - Method in class alluxio.grpc.FileInfo
optional bool mountPoint = 20;
hasMountPoint() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool mountPoint = 20;
hasMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
hasMountPoint() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool mount_point = 11;
hasMountPoint() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool mount_point = 11;
hasMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool mount_point = 2;
hasMountPoint() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
optional bool mount_point = 2;
hasMountPoint() - Method in interface alluxio.proto.journal.File.UpdateInodeDirectoryEntryOrBuilder
optional bool mount_point = 2;
hasMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
hasMoveJob() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
hasMoveJob() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
hasMsg() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
optional string msg = 1;
hasMsg() - Method in class alluxio.grpc.TransferLeaderMessage
optional string msg = 1;
hasMsg() - Method in interface alluxio.grpc.TransferLeaderMessageOrBuilder
optional string msg = 1;
hasName() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string name = 1;
hasName() - Method in class alluxio.grpc.ConfigProperty
optional string name = 1;
hasName() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string name = 1;
hasName() - Method in class alluxio.grpc.FileInfo.Builder
optional string name = 2;
hasName() - Method in class alluxio.grpc.FileInfo
optional string name = 2;
hasName() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string name = 2;
hasName() - Method in class alluxio.grpc.InconsistentProperty.Builder
optional string name = 1;
hasName() - Method in class alluxio.grpc.InconsistentProperty
optional string name = 1;
hasName() - Method in interface alluxio.grpc.InconsistentPropertyOrBuilder
optional string name = 1;
hasName() - Method in class alluxio.grpc.JobInfo.Builder
Some jobs don't have these
hasName() - Method in class alluxio.grpc.JobInfo
Some jobs don't have these
hasName() - Method in interface alluxio.grpc.JobInfoOrBuilder
Some jobs don't have these
hasName() - Method in class alluxio.grpc.ListAllPOptions.Builder
optional string name = 2;
hasName() - Method in class alluxio.grpc.ListAllPOptions
optional string name = 2;
hasName() - Method in interface alluxio.grpc.ListAllPOptionsOrBuilder
optional string name = 2;
hasName() - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
hasName() - Method in class alluxio.grpc.Metric
optional string name = 3;
hasName() - Method in interface alluxio.grpc.MetricOrBuilder
optional string name = 3;
hasName() - Method in class alluxio.grpc.PolicyInfo.Builder
optional string name = 2;
hasName() - Method in class alluxio.grpc.PolicyInfo
optional string name = 2;
hasName() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional string name = 2;
hasName() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
hasName() - Method in class alluxio.grpc.table.FieldSchema
optional string name = 2;
hasName() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string name = 2;
hasName() - Method in class alluxio.grpc.UfsStatus.Builder
optional string name = 1;
hasName() - Method in class alluxio.grpc.UfsStatus
optional string name = 1;
hasName() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string name = 1;
hasName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string name = 3;
hasName() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string name = 3;
hasName() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string name = 3;
hasName() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string name = 3;
hasName() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string name = 1;
hasName() - Method in class alluxio.proto.journal.Job.FileFilter
required string name = 1;
hasName() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
required string name = 1;
hasName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional string name = 2;
hasName() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional string name = 2;
hasName() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional string name = 2;
hasName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
optional string name = 1;
hasName() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
optional string name = 1;
hasName() - Method in interface alluxio.proto.journal.Policy.PolicyRemoveEntryOrBuilder
optional string name = 1;
hasName() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string name = 6;
hasName() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string name = 6;
hasName() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string name = 6;
hasName() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional string name = 1;
hasName() - Method in class alluxio.proto.shared.Acl.NamedAclActions
optional string name = 1;
hasName() - Method in interface alluxio.proto.shared.Acl.NamedAclActionsOrBuilder
optional string name = 1;
hasNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
hasNewBlock() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
hasNewBlock() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
hasNewName() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_name = 5;
hasNewName() - Method in class alluxio.proto.journal.File.RenameEntry
optional string new_name = 5;
hasNewName() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string new_name = 5;
hasNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 new_parent_id = 4;
hasNewParentId() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 new_parent_id = 4;
hasNewParentId() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 new_parent_id = 4;
hasNewPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_path = 7;
hasNewPath() - Method in class alluxio.proto.journal.File.RenameEntry
optional string new_path = 7;
hasNewPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string new_path = 7;
hasNext() - Method in class alluxio.master.file.meta.InodeTreeBufferedIterator
 
hasNext() - Method in class alluxio.master.job.FileIterable.FileIterator
 
hasNext() - Method in class alluxio.resource.CloseableIterator
 
hasNext() - Method in class alluxio.underfs.ObjectUnderFileSystem.UfsStatusIterator
 
hasNext() - Method in class alluxio.worker.block.BlockMapIterator
 
hasNext() - Method in class alluxio.worker.block.RegisterStreamer
 
hasNextChunk() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Gets if there is more chunks to fetch WITHOUT actually fetching the next chunk.
hasNextChunk() - Method in class alluxio.underfs.s3a.S3AUnderFileSystem.S3AObjectListingChunk
 
hasNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
optional int64 next_container_id = 1;
hasNextContainerId() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
optional int64 next_container_id = 1;
hasNextContainerId() - Method in interface alluxio.proto.journal.Block.BlockContainerIdGeneratorEntryOrBuilder
optional int64 next_container_id = 1;
hasNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set, do not try to cache the block locally when reading the data from the UFS.
hasNoCache() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
If set, do not try to cache the block locally when reading the data from the UFS.
hasNoCache() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
If set, do not try to cache the block locally when reading the data from the UFS.
hasNodeLocalWorker() - Method in class alluxio.client.file.FileSystemContext
 
hasNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
optional .alluxio.grpc.journal.NodeState node_state = 1;
hasNodeState() - Method in class alluxio.grpc.GetNodeStatePResponse
optional .alluxio.grpc.journal.NodeState node_state = 1;
hasNodeState() - Method in interface alluxio.grpc.GetNodeStatePResponseOrBuilder
optional .alluxio.grpc.journal.NodeState node_state = 1;
hasNoRestriction() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location has no restriction, i.e., BlockStoreLocation.ANY_TIER_LOCATION.
hasNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 numActiveTasks = 6;
hasNumActiveTasks() - Method in class alluxio.grpc.JobWorkerHealth
optional int32 numActiveTasks = 6;
hasNumActiveTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int32 numActiveTasks = 6;
hasNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.DateColumnStatsData
optional int64 num_distincts = 4;
hasNumDistincts() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional int64 num_distincts = 4;
hasNumDistincts() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional int64 num_distincts = 4;
hasNumDistincts() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 num_distincts = 4;
hasNumDistincts() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_distincts = 4;
hasNumDistincts() - Method in class alluxio.grpc.table.StringColumnStatsData
optional int64 num_distincts = 4;
hasNumDistincts() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional int64 num_distincts = 4;
hasNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_falses = 2;
hasNumFalses() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional int64 num_falses = 2;
hasNumFalses() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional int64 num_falses = 2;
hasNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.BinaryColumnStatsData
optional int64 num_nulls = 3;
hasNumNulls() - Method in interface alluxio.grpc.table.BinaryColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional int64 num_nulls = 3;
hasNumNulls() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.DateColumnStatsData
optional int64 num_nulls = 3;
hasNumNulls() - Method in interface alluxio.grpc.table.DateColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.DecimalColumnStatsData
optional int64 num_nulls = 3;
hasNumNulls() - Method in interface alluxio.grpc.table.DecimalColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.DoubleColumnStatsData
optional int64 num_nulls = 3;
hasNumNulls() - Method in interface alluxio.grpc.table.DoubleColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.LongColumnStatsData
optional int64 num_nulls = 3;
hasNumNulls() - Method in interface alluxio.grpc.table.LongColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_nulls = 3;
hasNumNulls() - Method in class alluxio.grpc.table.StringColumnStatsData
optional int64 num_nulls = 3;
hasNumNulls() - Method in interface alluxio.grpc.table.StringColumnStatsDataOrBuilder
optional int64 num_nulls = 3;
hasNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_trues = 1;
hasNumTrues() - Method in class alluxio.grpc.table.BooleanColumnStatsData
optional int64 num_trues = 1;
hasNumTrues() - Method in interface alluxio.grpc.table.BooleanColumnStatsDataOrBuilder
optional int64 num_trues = 1;
hasOffset() - Method in class alluxio.grpc.FileBlockInfo.Builder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.grpc.FileBlockInfo
optional int64 offset = 2;
hasOffset() - Method in interface alluxio.grpc.FileBlockInfoOrBuilder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.grpc.ReadRequest
optional int64 offset = 2;
hasOffset() - Method in interface alluxio.grpc.ReadRequestOrBuilder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
hasOffset() - Method in class alluxio.grpc.SnapshotData
Deprecated. 
hasOffset() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
Deprecated. 
hasOffset() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 offset = 3;
hasOffset() - Method in class alluxio.grpc.WriteRequestCommand
optional int64 offset = 3;
hasOffset() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional int64 offset = 3;
hasOffset() - Method in class alluxio.grpc.WriteResponse.Builder
optional int64 offset = 1;
hasOffset() - Method in class alluxio.grpc.WriteResponse
optional int64 offset = 1;
hasOffset() - Method in interface alluxio.grpc.WriteResponseOrBuilder
optional int64 offset = 1;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
optional int64 offset = 2;
hasOffset() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
optional int64 offset = 2;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
hasOffset() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional int64 offset = 3;
hasOffset() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional int64 offset = 3;
hasOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only start listing items after this many items have been processed.
hasOffsetCount() - Method in class alluxio.grpc.ListStatusPartialPOptions
Only start listing items after this many items have been processed.
hasOffsetCount() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Only start listing items after this many items have been processed.
hasOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
hasOffsetId() - Method in class alluxio.grpc.ListStatusPartialPOptions
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
hasOffsetId() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
hasOffsetInFile() - Method in class alluxio.grpc.Block.Builder
The offset of the block in within ufs the file.
hasOffsetInFile() - Method in class alluxio.grpc.Block
The offset of the block in within ufs the file.
hasOffsetInFile() - Method in interface alluxio.grpc.BlockOrBuilder
The offset of the block in within ufs the file.
hasOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The offset of the block in within the file.
hasOffsetInFile() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
The offset of the block in within the file.
hasOffsetInFile() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
The offset of the block in within the file.
hasOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated. 
hasOffsetReceived() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated. 
hasOffsetReceived() - Method in interface alluxio.grpc.DownloadSnapshotPRequestOrBuilder
Deprecated. 
hasOffsetReceived() - Method in class alluxio.grpc.ReadRequest.Builder
Read receipt
hasOffsetReceived() - Method in class alluxio.grpc.ReadRequest
Read receipt
hasOffsetReceived() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Read receipt
hasOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated. 
hasOffsetReceived() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated. 
hasOffsetReceived() - Method in interface alluxio.grpc.UploadSnapshotPResponseOrBuilder
Deprecated. 
hasOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
If set, only reserve space for the block.
hasOnlyReserveSpace() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
If set, only reserve space for the block.
hasOnlyReserveSpace() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
If set, only reserve space for the block.
hasOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.grpc.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.grpc.CacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
hasOpenUfsBlockOptions() - Method in class alluxio.grpc.ReadRequest
This is only set for UFS block read.
hasOpenUfsBlockOptions() - Method in interface alluxio.grpc.ReadRequestOrBuilder
This is only set for UFS block read.
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
hasOpenUfsBlockOptions() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
This is only set for UFS block read.
hasOpenUfsBlockOptions() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
This is only set for UFS block read.
hasOperation() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string operation = 1;
hasOperation() - Method in class alluxio.grpc.AddPolicyPOptions
optional string operation = 1;
hasOperation() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string operation = 1;
hasOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
hasOperationId() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional .alluxio.grpc.file.FsOpPId operationId = 4;
hasOperationId() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
hasOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
hasOperationId() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
hasOperationId() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
hasOperationType() - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional .alluxio.grpc.job.OperationType operationType = 3;
hasOperationType() - Method in class alluxio.grpc.CmdStatusBlock
optional .alluxio.grpc.job.OperationType operationType = 3;
hasOperationType() - Method in interface alluxio.grpc.CmdStatusBlockOrBuilder
optional .alluxio.grpc.job.OperationType operationType = 3;
hasOperationType() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.OperationType operationType = 2;
hasOperationType() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.OperationType operationType = 2;
hasOperationType() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.OperationType operationType = 2;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 op_time_ms = 4;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional int64 op_time_ms = 4;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional int64 op_time_ms = 4;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.PersistFileEntry
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.PersistFileEntryOrBuilder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.RenameEntry
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional int64 op_time_ms = 3;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 op_time_ms = 2;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAclEntry
optional int64 op_time_ms = 2;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional int64 op_time_ms = 2;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
hasOpTimeMs() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 op_time_ms = 2;
hasOpTimeMs() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 op_time_ms = 2;
hasOptions() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.AddPolicyPRequest
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.BackupPRequest
optional .alluxio.grpc.meta.BackupPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
hasOptions() - Method in class alluxio.grpc.BlockHeartbeatPRequest
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
hasOptions() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
hasOptions() - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CancelPRequest
optional .alluxio.grpc.job.CancelPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.CancelPRequestOrBuilder
optional .alluxio.grpc.job.CancelPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CheckAccessPRequest
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CheckConsistencyPRequest
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
hasOptions() - Method in class alluxio.grpc.CommitBlockPRequest
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
hasOptions() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
hasOptions() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CompleteFilePRequest
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CreateDirectoryPRequest
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.CreateFilePRequest
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.DeletePRequest
optional .alluxio.grpc.file.DeletePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
optional .alluxio.grpc.file.DeletePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ExistsPRequest
optional .alluxio.grpc.file.ExistsPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.FreePRequest
optional .alluxio.grpc.file.FreePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.FreePRequestOrBuilder
optional .alluxio.grpc.file.FreePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
hasOptions() - Method in class alluxio.grpc.GetActionInfoRequest
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
hasOptions() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
hasOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.GetAllMasterStatusPRequestOrBuilder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.GetAllWorkerHealthPRequestOrBuilder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetBlockInfoPRequest
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetBlockInfoPRequestOrBuilder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetCmdStatusDetailedRequestOrBuilder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetCmdStatusRequest
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetCmdStatusRequestOrBuilder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetFileInfoPRequest
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetFileInfoPRequestOrBuilder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobMasterIdPRequest
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetJobMasterIdPRequestOrBuilder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobProgressPRequest
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetJobProgressPRequestOrBuilder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.GetJobServiceSummaryPRequestOrBuilder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetJobStatusDetailedPRequestOrBuilder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetJobStatusPRequest
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetJobStatusPRequestOrBuilder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetMasterIdPRequest
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetMasterIdPRequestOrBuilder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.GetPinnedFileIdsPRequestOrBuilder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetPolicyStatusPRequest
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetQuorumInfoPRequest
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.GetQuorumInfoPRequestOrBuilder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
hasOptions() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
hasOptions() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
hasOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.GetStateLockHoldersPRequestOrBuilder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetStatusPRequest
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetUfsInfoPRequest
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetUfsInfoPRequestOrBuilder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.GetWorkerIdPRequest
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.JobHeartbeatPRequest
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.JobHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.JobMasterHeartbeatPRequestOrBuilder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListAllPRequest
optional .alluxio.grpc.job.ListAllPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.ListAllPRequestOrBuilder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListPolicyPRequest
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.ListPolicyPRequestOrBuilder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListProxyStatusPRequest
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.ListProxyStatusPRequestOrBuilder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListStatusPartialPOptions
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ListStatusPartialPRequest
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ListStatusPRequest
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
hasOptions() - Method in class alluxio.grpc.LoadFileRequest
required .alluxio.grpc.block.UfsReadOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
required .alluxio.grpc.block.UfsReadOptions options = 2;
hasOptions() - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
hasOptions() - Method in class alluxio.grpc.LoadRequest
required .alluxio.grpc.block.UfsReadOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.LoadRequestOrBuilder
required .alluxio.grpc.block.UfsReadOptions options = 2;
hasOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.MasterHeartbeatPRequest
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.MasterHeartbeatPRequestOrBuilder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.MetricsHeartbeatPRequestOrBuilder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.MountPRequest
optional .alluxio.grpc.file.MountPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.MountPRequestOrBuilder
optional .alluxio.grpc.file.MountPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
hasOptions() - Method in class alluxio.grpc.PolicyInfo
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
hasOptions() - Method in interface alluxio.grpc.PolicyInfoOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
hasOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.ProxyHeartbeatPRequestOrBuilder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RegisterJobMasterPRequest
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.RegisterJobMasterPRequestOrBuilder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RegisterMasterPRequest
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.RegisterMasterPRequestOrBuilder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
hasOptions() - Method in class alluxio.grpc.RegisterWorkerPRequest
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
hasOptions() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
hasOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RemovePolicyPRequest
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
hasOptions() - Method in class alluxio.grpc.RenamePRequest
optional .alluxio.grpc.file.RenamePOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
optional .alluxio.grpc.file.RenamePOptions options = 3;
hasOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.ResetPrioritiesPRequest
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.ResetPrioritiesPRequestOrBuilder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.RunPRequest
optional .alluxio.grpc.job.RunPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.RunPRequestOrBuilder
optional .alluxio.grpc.job.RunPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
hasOptions() - Method in class alluxio.grpc.SetAclPRequest
the method options
hasOptions() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the method options
hasOptions() - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.SetAttributePRequest
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.SetPathConfigurationPRequest
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
hasOptions() - Method in class alluxio.grpc.SubmitRequest
optional .alluxio.grpc.job.SubmitOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.SubmitRequestOrBuilder
optional .alluxio.grpc.job.SubmitOptions options = 2;
hasOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.TransferLeadershipPRequest
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
hasOptions() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
hasOptions() - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.UnmountPRequest
optional .alluxio.grpc.file.UnmountPOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.UnmountPRequestOrBuilder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
hasOptions() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.UpdateMountPRequest
optional .alluxio.grpc.file.MountPOptions options = 3;
hasOptions() - Method in interface alluxio.grpc.UpdateMountPRequestOrBuilder
optional .alluxio.grpc.file.MountPOptions options = 3;
hasOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
hasOptions() - Method in class alluxio.grpc.UpdateUfsModePRequest
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
hasOptions() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
hasOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
hasOptions() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
hasOptions() - Method in interface alluxio.proto.journal.Policy.PolicyDefinitionEntryOrBuilder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
hasOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
hasOrder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
hasOrder() - Method in interface alluxio.grpc.table.layout.hive.SortingColumnOrBuilder
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
hasOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
hasOtherActions() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional .alluxio.proto.shared.AclActions otherActions = 6;
hasOtherActions() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional .alluxio.proto.shared.AclActions otherActions = 6;
hasOtherBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits otherBits = 3;
hasOtherBits() - Method in class alluxio.grpc.PMode
required .alluxio.grpc.Bits otherBits = 3;
hasOtherBits() - Method in interface alluxio.grpc.PModeOrBuilder
required .alluxio.grpc.Bits otherBits = 3;
hasOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string output_format = 3;
hasOutputFormat() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string output_format = 3;
hasOutputFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string output_format = 3;
hasOverwrite() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool overwrite = 4;
hasOverwrite() - Method in class alluxio.grpc.CopyJobPOptions
optional bool overwrite = 4;
hasOverwrite() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool overwrite = 4;
hasOverwrite() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool overwrite = 13;
hasOverwrite() - Method in class alluxio.grpc.CreateFilePOptions
optional bool overwrite = 13;
hasOverwrite() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool overwrite = 13;
hasOverwrite() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool overwrite = 4;
hasOverwrite() - Method in class alluxio.grpc.MoveJobPOptions
optional bool overwrite = 4;
hasOverwrite() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool overwrite = 4;
hasOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool overwrite = 1;
hasOverwrite() - Method in class alluxio.grpc.S3SyntaxOptions
optional bool overwrite = 1;
hasOverwrite() - Method in interface alluxio.grpc.S3SyntaxOptionsOrBuilder
optional bool overwrite = 1;
hasOverwrite() - Method in class alluxio.grpc.WriteOptions.Builder
optional bool overwrite = 1;
hasOverwrite() - Method in class alluxio.grpc.WriteOptions
optional bool overwrite = 1;
hasOverwrite() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
optional bool overwrite = 1;
hasOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool overwrite = 10;
hasOverwrite() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional bool overwrite = 10;
hasOverwrite() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional bool overwrite = 10;
hasOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool overwrite = 10;
hasOverwrite() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional bool overwrite = 10;
hasOverwrite() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional bool overwrite = 10;
hasOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_access_time = 19;
hasOverwriteAccessTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional bool overwrite_access_time = 19;
hasOverwriteAccessTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional bool overwrite_access_time = 19;
hasOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_modification_time = 8;
hasOverwriteModificationTime() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional bool overwrite_modification_time = 8;
hasOverwriteModificationTime() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional bool overwrite_modification_time = 8;
hasOwner() - Method in class alluxio.grpc.FileInfo.Builder
optional string owner = 16;
hasOwner() - Method in class alluxio.grpc.FileInfo
optional string owner = 16;
hasOwner() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string owner = 16;
hasOwner() - Method in class alluxio.grpc.PAcl.Builder
optional string owner = 1;
hasOwner() - Method in class alluxio.grpc.PAcl
optional string owner = 1;
hasOwner() - Method in interface alluxio.grpc.PAclOrBuilder
optional string owner = 1;
hasOwner() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string owner = 3;
hasOwner() - Method in class alluxio.grpc.SetAttributePOptions
optional string owner = 3;
hasOwner() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional string owner = 3;
hasOwner() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string owner = 4;
hasOwner() - Method in class alluxio.grpc.table.TableInfo
optional string owner = 4;
hasOwner() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string owner = 4;
hasOwner() - Method in class alluxio.grpc.UfsStatus.Builder
optional string owner = 4;
hasOwner() - Method in class alluxio.grpc.UfsStatus
optional string owner = 4;
hasOwner() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string owner = 4;
hasOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
hasOwner() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string owner = 2;
hasOwner() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string owner = 2;
hasOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
hasOwner() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string owner = 8;
hasOwner() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string owner = 8;
hasOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
hasOwner() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string owner = 14;
hasOwner() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string owner = 14;
hasOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
hasOwner() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string owner = 6;
hasOwner() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string owner = 6;
hasOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string owner = 9;
hasOwner() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string owner = 9;
hasOwner() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string owner = 9;
hasOwnerBits() - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits ownerBits = 1;
hasOwnerBits() - Method in class alluxio.grpc.PMode
required .alluxio.grpc.Bits ownerBits = 1;
hasOwnerBits() - Method in interface alluxio.grpc.PModeOrBuilder
required .alluxio.grpc.Bits ownerBits = 1;
hasOwnerName() - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
hasOwnerName() - Method in class alluxio.grpc.table.Database
optional string owner_name = 5;
hasOwnerName() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional string owner_name = 5;
hasOwnerType() - Method in class alluxio.grpc.table.Database.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
hasOwnerType() - Method in class alluxio.grpc.table.Database
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
hasOwnerType() - Method in interface alluxio.grpc.table.DatabaseOrBuilder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
hasOwningGroup() - Method in class alluxio.grpc.PAcl.Builder
optional string owningGroup = 2;
hasOwningGroup() - Method in class alluxio.grpc.PAcl
optional string owningGroup = 2;
hasOwningGroup() - Method in interface alluxio.grpc.PAclOrBuilder
optional string owningGroup = 2;
hasOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningGroup = 2;
hasOwningGroup() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional string owningGroup = 2;
hasOwningGroup() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional string owningGroup = 2;
hasOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningUser = 1;
hasOwningUser() - Method in class alluxio.proto.shared.Acl.AccessControlList
optional string owningUser = 1;
hasOwningUser() - Method in interface alluxio.proto.shared.Acl.AccessControlListOrBuilder
optional string owningUser = 1;
hasPage(PageId) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
hasPage(PageId) - Method in interface alluxio.client.file.cache.PageMetaStore
 
hasPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 pageSize = 1;
hasPageSize() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
optional int64 pageSize = 1;
hasPageSize() - Method in interface alluxio.proto.client.Cache.PPageStoreCommonOptionsOrBuilder
optional int64 pageSize = 1;
hasParentId() - Method in class alluxio.grpc.JobInfo.Builder
optional int64 parentId = 10;
hasParentId() - Method in class alluxio.grpc.JobInfo
optional int64 parentId = 10;
hasParentId() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional int64 parentId = 10;
hasParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 parent_id = 2;
hasParentId() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 parent_id = 2;
hasParentId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 parent_id = 2;
hasParentId() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 parent_id = 2;
hasParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 parent_id = 7;
hasParentId() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 parent_id = 7;
hasParentId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 parent_id = 7;
hasPartialListing() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool partialListing = 3;
hasPartialListing() - Method in class alluxio.grpc.CopyJobPOptions
optional bool partialListing = 3;
hasPartialListing() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool partialListing = 3;
hasPartialListing() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool partialListing = 3;
hasPartialListing() - Method in class alluxio.grpc.LoadJobPOptions
optional bool partialListing = 3;
hasPartialListing() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool partialListing = 3;
hasPartialListing() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool partialListing = 3;
hasPartialListing() - Method in class alluxio.grpc.MoveJobPOptions
optional bool partialListing = 3;
hasPartialListing() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool partialListing = 3;
hasPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool partialListing = 7;
hasPartialListing() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required bool partialListing = 7;
hasPartialListing() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required bool partialListing = 7;
hasPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool partialListing = 6;
hasPartialListing() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required bool partialListing = 6;
hasPartialListing() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required bool partialListing = 6;
hasPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool partialListing = 7;
hasPartialListing() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required bool partialListing = 7;
hasPartialListing() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required bool partialListing = 7;
hasPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
partition name in the form of "key=value"
hasPartitionName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
partition name in the form of "key=value"
hasPartitionName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
partition name in the form of "key=value"
hasPartitionSpec() - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
hasPartitionSpec() - Method in class alluxio.grpc.table.Partition
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
hasPartitionSpec() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
hasPath() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.CheckAccessPRequest
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.CheckAccessPRequestOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
the root of the subtree to check
hasPath() - Method in class alluxio.grpc.CheckConsistencyPRequest
the root of the subtree to check
hasPath() - Method in interface alluxio.grpc.CheckConsistencyPRequestOrBuilder
the root of the subtree to check
hasPath() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
the path of the file
hasPath() - Method in class alluxio.grpc.CompleteFilePRequest
the path of the file
hasPath() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
the path of the file
hasPath() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
the path of the directory
hasPath() - Method in class alluxio.grpc.CreateDirectoryPRequest
the path of the directory
hasPath() - Method in interface alluxio.grpc.CreateDirectoryPRequestOrBuilder
the path of the directory
hasPath() - Method in class alluxio.grpc.CreateFilePRequest.Builder
the path of the file
hasPath() - Method in class alluxio.grpc.CreateFilePRequest
the path of the file
hasPath() - Method in interface alluxio.grpc.CreateFilePRequestOrBuilder
the path of the file
hasPath() - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.DeletePRequest
the path of the file or directory
hasPath() - Method in interface alluxio.grpc.DeletePRequestOrBuilder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.ExistsPRequest.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.ExistsPRequest
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.ExistsPRequestOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.FileInfo.Builder
optional string path = 3;
hasPath() - Method in class alluxio.grpc.FileInfo
optional string path = 3;
hasPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string path = 3;
hasPath() - Method in class alluxio.grpc.FreePRequest.Builder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.FreePRequest
the path of the file or directory
hasPath() - Method in interface alluxio.grpc.FreePRequestOrBuilder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.GetFilePathPResponse
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.GetFilePathPResponseOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
the path of the file
hasPath() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
the path of the file
hasPath() - Method in interface alluxio.grpc.GetNewBlockIdForFilePRequestOrBuilder
the path of the file
hasPath() - Method in class alluxio.grpc.GetStatusPRequest.Builder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.GetStatusPRequest
the path of the file or directory
hasPath() - Method in interface alluxio.grpc.GetStatusPRequestOrBuilder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.JobDescription.Builder
optional string path = 2;
hasPath() - Method in class alluxio.grpc.JobDescription
optional string path = 2;
hasPath() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
optional string path = 2;
hasPath() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.ListStatusPartialPRequest
the path of the file or directory
hasPath() - Method in interface alluxio.grpc.ListStatusPartialPRequestOrBuilder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.ListStatusPRequest.Builder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.ListStatusPRequest
the path of the file or directory
hasPath() - Method in interface alluxio.grpc.ListStatusPRequestOrBuilder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
required string path = 1;
hasPath() - Method in class alluxio.grpc.NeedsSyncRequest
required string path = 1;
hasPath() - Method in interface alluxio.grpc.NeedsSyncRequestOrBuilder
required string path = 1;
hasPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.RemovePathConfigurationPRequestOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.RenamePRequest.Builder
the source path of the file or directory
hasPath() - Method in class alluxio.grpc.RenamePRequest
the source path of the file or directory
hasPath() - Method in interface alluxio.grpc.RenamePRequestOrBuilder
the source path of the file or directory
hasPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
the path of the file
hasPath() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
the path of the file
hasPath() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePRequestOrBuilder
the path of the file
hasPath() - Method in class alluxio.grpc.SetAclPRequest.Builder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.SetAclPRequest
the path of the file or directory
hasPath() - Method in interface alluxio.grpc.SetAclPRequestOrBuilder
the path of the file or directory
hasPath() - Method in class alluxio.grpc.SetAttributePRequest.Builder
the path of the file
hasPath() - Method in class alluxio.grpc.SetAttributePRequest
the path of the file
hasPath() - Method in interface alluxio.grpc.SetAttributePRequestOrBuilder
the path of the file
hasPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional string path = 1;
hasPath() - Method in class alluxio.grpc.SetPathConfigurationPRequest
optional string path = 1;
hasPath() - Method in interface alluxio.grpc.SetPathConfigurationPRequestOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
optional string path = 1;
hasPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateResponseOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
hasPath() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
optional string path = 1;
hasPath() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenResponseOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional string path = 5;
hasPath() - Method in class alluxio.proto.journal.File.DeleteFileEntry
optional string path = 5;
hasPath() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
optional string path = 5;
hasPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string path = 17;
hasPath() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string path = 17;
hasPath() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string path = 17;
hasPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string path = 25;
hasPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string path = 25;
hasPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string path = 25;
hasPath() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string path = 6;
hasPath() - Method in class alluxio.proto.journal.File.RenameEntry
optional string path = 6;
hasPath() - Method in interface alluxio.proto.journal.File.RenameEntryOrBuilder
optional string path = 6;
hasPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string path = 12;
hasPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional string path = 12;
hasPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional string path = 12;
hasPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
optional string path = 1;
hasPath() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
optional string path = 1;
hasPath() - Method in interface alluxio.proto.journal.Meta.PathPropertiesEntryOrBuilder
optional string path = 1;
hasPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
optional string path = 1;
hasPath() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
optional string path = 1;
hasPath() - Method in interface alluxio.proto.journal.Meta.RemovePathPropertiesEntryOrBuilder
optional string path = 1;
hasPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string pathConfigHash = 2;
hasPathConfigHash() - Method in class alluxio.grpc.GetConfigHashPResponse
optional string pathConfigHash = 2;
hasPathConfigHash() - Method in interface alluxio.grpc.GetConfigHashPResponseOrBuilder
optional string pathConfigHash = 2;
hasPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string pathConfigHash = 4;
hasPathConfigHash() - Method in class alluxio.grpc.GetConfigurationPResponse
optional string pathConfigHash = 4;
hasPathConfigHash() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional string pathConfigHash = 4;
hasPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 pathConfigLastUpdateTime = 6;
hasPathConfigLastUpdateTime() - Method in class alluxio.grpc.GetConfigurationPResponse
optional int64 pathConfigLastUpdateTime = 6;
hasPathConfigLastUpdateTime() - Method in interface alluxio.grpc.GetConfigurationPResponseOrBuilder
optional int64 pathConfigLastUpdateTime = 6;
hasPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
hasPathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
hasPathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
hasPattern() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
optional string pattern = 2;
hasPattern() - Method in class alluxio.proto.journal.Job.FileFilter
optional string pattern = 2;
hasPattern() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
optional string pattern = 2;
hasPayload() - Method in class alluxio.network.protocol.RPCMessage
Returns true if the message has a payload.
hasPayload() - Method in class alluxio.network.protocol.RPCProtoMessage
 
hasPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
hasPermission() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 permission = 8;
hasPermission() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 permission = 8;
hasPersist() - Method in class alluxio.grpc.RenamePOptions.Builder
optional bool persist = 2;
hasPersist() - Method in class alluxio.grpc.RenamePOptions
optional bool persist = 2;
hasPersist() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional bool persist = 2;
hasPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
hasPersistDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
hasPersistDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
hasPersisted() - Method in class alluxio.grpc.FileInfo.Builder
optional bool persisted = 12;
hasPersisted() - Method in class alluxio.grpc.FileInfo
optional bool persisted = 12;
hasPersisted() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool persisted = 12;
hasPersisted() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool persisted = 2;
hasPersisted() - Method in class alluxio.grpc.SetAttributePOptions
optional bool persisted = 2;
hasPersisted() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool persisted = 2;
hasPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
hasPersisted() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool persisted = 5;
hasPersisted() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool persisted = 5;
hasPersistenceState() - Method in class alluxio.grpc.FileInfo.Builder
optional string persistenceState = 19;
hasPersistenceState() - Method in class alluxio.grpc.FileInfo
optional string persistenceState = 19;
hasPersistenceState() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string persistenceState = 19;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional string persistence_state = 4;
hasPersistenceState() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string persistence_state = 4;
hasPersistenceState() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string persistence_state = 4;
hasPersistenceState() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string persistence_state = 4;
hasPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persistence_state = 8;
hasPersistenceState() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string persistence_state = 8;
hasPersistenceState() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string persistence_state = 8;
hasPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 persistenceWaitTime = 10;
hasPersistenceWaitTime() - Method in class alluxio.grpc.CreateFilePOptions
optional int64 persistenceWaitTime = 10;
hasPersistenceWaitTime() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int64 persistenceWaitTime = 10;
hasPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional int64 persistenceWaitTime = 2;
hasPersistenceWaitTime() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
optional int64 persistenceWaitTime = 2;
hasPersistenceWaitTime() - Method in interface alluxio.grpc.ScheduleAsyncPersistencePOptionsOrBuilder
optional int64 persistenceWaitTime = 2;
hasPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 persist_job_id = 22;
hasPersistJobId() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 persist_job_id = 22;
hasPersistJobId() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 persist_job_id = 22;
hasPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 persistJobId = 11;
hasPersistJobId() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 persistJobId = 11;
hasPersistJobId() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 persistJobId = 11;
hasPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 persist_job_id = 10;
hasPersistJobId() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int64 persist_job_id = 10;
hasPersistJobId() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int64 persist_job_id = 10;
hasPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Used for recovering in-progress file persist jobs on master start.
hasPersistJobId() - Method in class alluxio.proto.meta.InodeMeta.Inode
Used for recovering in-progress file persist jobs on master start.
hasPersistJobId() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
Used for recovering in-progress file persist jobs on master start.
hasPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persist_job_temp_ufs_path = 24;
hasPersistJobTempUfsPath() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string persist_job_temp_ufs_path = 24;
hasPersistJobTempUfsPath() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string persist_job_temp_ufs_path = 24;
hasPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
hasPersistOptions() - Method in class alluxio.grpc.FileSystemCommandOptions
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
hasPersistOptions() - Method in interface alluxio.grpc.FileSystemCommandOptionsOrBuilder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
hasPinned() - Method in class alluxio.grpc.FileInfo.Builder
optional bool pinned = 10;
hasPinned() - Method in class alluxio.grpc.FileInfo
optional bool pinned = 10;
hasPinned() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional bool pinned = 10;
hasPinned() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool pinned = 1;
hasPinned() - Method in class alluxio.grpc.SetAttributePOptions
optional bool pinned = 1;
hasPinned() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool pinned = 1;
hasPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional bool pinned = 5;
hasPinned() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional bool pinned = 5;
hasPinned() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool pinned = 3;
hasPinned() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional bool pinned = 3;
hasPinned() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional bool pinned = 3;
hasPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool pinned = 5;
hasPinned() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional bool pinned = 5;
hasPinned() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional bool pinned = 5;
hasPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool pin_on_create = 9;
hasPinOnCreate() - Method in class alluxio.grpc.WriteRequestCommand
optional bool pin_on_create = 9;
hasPinOnCreate() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional bool pin_on_create = 9;
hasPolicy() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
hasPolicy() - Method in class alluxio.grpc.AddPolicyPResponse
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
hasPolicy() - Method in interface alluxio.grpc.AddPolicyPResponseOrBuilder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
hasPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
hasPolicyDefinition() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
hasPolicyDefinition() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
hasPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.AddPolicyPRequest
optional string policyName = 1;
hasPolicyName() - Method in interface alluxio.grpc.AddPolicyPRequestOrBuilder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.GetActionInfoRequest
optional string policyName = 1;
hasPolicyName() - Method in interface alluxio.grpc.GetActionInfoRequestOrBuilder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.GetPolicyStatusPRequest
optional string policyName = 1;
hasPolicyName() - Method in interface alluxio.grpc.GetPolicyStatusPRequestOrBuilder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.RemovePolicyPRequest
optional string policyName = 1;
hasPolicyName() - Method in interface alluxio.grpc.RemovePolicyPRequestOrBuilder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
optional string policyName = 1;
hasPolicyName() - Method in class alluxio.grpc.TriggerPolicyRequest
optional string policyName = 1;
hasPolicyName() - Method in interface alluxio.grpc.TriggerPolicyRequestOrBuilder
optional string policyName = 1;
hasPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
hasPolicyRemove() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
hasPolicyRemove() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
hasPositionShort() - Method in class alluxio.grpc.ReadRequest.Builder
Is position read to a small buffer
hasPositionShort() - Method in class alluxio.grpc.ReadRequest
Is position read to a small buffer
hasPositionShort() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Is position read to a small buffer
hasPositionShort() - Method in class alluxio.grpc.UfsReadOptions.Builder
is position short or not, used for HDFS performance optimization.
hasPositionShort() - Method in class alluxio.grpc.UfsReadOptions
is position short or not, used for HDFS performance optimization.
hasPositionShort() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
is position short or not, used for HDFS performance optimization.
hasPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only match files with a given prefix.
hasPrefix() - Method in class alluxio.grpc.ListStatusPartialPOptions
Only match files with a given prefix.
hasPrefix() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Only match files with a given prefix.
hasPrefix(String, String) - Static method in class alluxio.util.io.PathUtils
Checks whether the given path contains the given prefix.
hasPreviousVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 previous_version = 9;
hasPreviousVersion() - Method in class alluxio.grpc.table.TableInfo
optional int64 previous_version = 9;
hasPreviousVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional int64 previous_version = 9;
hasPriority() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional int32 priority = 4;
hasPriority() - Method in class alluxio.grpc.QuorumServerInfo
optional int32 priority = 4;
hasPriority() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional int32 priority = 4;
hasProcessLocalWorker() - Method in class alluxio.client.file.FileSystemContext
 
hasProgressPercentage() - Method in class alluxio.grpc.CmdSummary.Builder
optional float progressPercentage = 9;
hasProgressPercentage() - Method in class alluxio.grpc.CmdSummary
optional float progressPercentage = 9;
hasProgressPercentage() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional float progressPercentage = 9;
hasProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional string progressReport = 1;
hasProgressReport() - Method in class alluxio.grpc.GetJobProgressPResponse
optional string progressReport = 1;
hasProgressReport() - Method in interface alluxio.grpc.GetJobProgressPResponseOrBuilder
optional string progressReport = 1;
hasPromote() - Method in class alluxio.grpc.ReadRequest.Builder
Whether the block should be promoted before reading
hasPromote() - Method in class alluxio.grpc.ReadRequest
Whether the block should be promoted before reading
hasPromote() - Method in interface alluxio.grpc.ReadRequestOrBuilder
Whether the block should be promoted before reading
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
optional bool promote = 2;
hasPromote() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockOpenRequestOrBuilder
optional bool promote = 2;
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
Whether the block should be promoted before reading
hasPromote() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
Whether the block should be promoted before reading
hasPromote() - Method in interface alluxio.proto.dataserver.Protocol.ReadRequestOrBuilder
Whether the block should be promoted before reading
hasProperties() - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
hasProperties() - Method in class alluxio.grpc.UfsInfo
optional .alluxio.grpc.file.MountPOptions properties = 2;
hasProperties() - Method in interface alluxio.grpc.UfsInfoOrBuilder
optional .alluxio.grpc.file.MountPOptions properties = 2;
hasProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
hasProxyAddress() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional .alluxio.grpc.NetAddress proxyAddress = 1;
hasProxyAddress() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
hasProxyFor(InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingProxy
 
hasQueuedSubmissions() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
hasRaftJournal() - Method in class alluxio.grpc.MasterInfo.Builder
optional bool raftJournal = 12;
hasRaftJournal() - Method in class alluxio.grpc.MasterInfo
optional bool raftJournal = 12;
hasRaftJournal() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional bool raftJournal = 12;
hasRange() - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
hasRange() - Method in class alluxio.grpc.table.Domain
.alluxio.grpc.table.RangeSet range = 1;
hasRange() - Method in interface alluxio.grpc.table.DomainOrBuilder
.alluxio.grpc.table.RangeSet range = 1;
hasRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool rawValue = 1;
hasRawValue() - Method in class alluxio.grpc.GetConfigurationPOptions
optional bool rawValue = 1;
hasRawValue() - Method in interface alluxio.grpc.GetConfigurationPOptionsOrBuilder
optional bool rawValue = 1;
hasReadOnly() - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool readOnly = 5;
hasReadOnly() - Method in class alluxio.grpc.MountPointInfo
optional bool readOnly = 5;
hasReadOnly() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional bool readOnly = 5;
hasReadOnly() - Method in class alluxio.grpc.MountPOptions.Builder
optional bool readOnly = 1;
hasReadOnly() - Method in class alluxio.grpc.MountPOptions
optional bool readOnly = 1;
hasReadOnly() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
optional bool readOnly = 1;
hasReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
hasReadOnly() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool readOnly = 3;
hasReadOnly() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool readOnly = 3;
hasReadType() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.ReadPType readType = 1;
hasReadType() - Method in class alluxio.grpc.OpenFilePOptions
optional .alluxio.grpc.file.ReadPType readType = 1;
hasReadType() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional .alluxio.grpc.file.ReadPType readType = 1;
hasRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool recursive = 1;
hasRecursive() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional bool recursive = 1;
hasRecursive() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional bool recursive = 1;
hasRecursive() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool recursive = 2;
hasRecursive() - Method in class alluxio.grpc.CreateFilePOptions
optional bool recursive = 2;
hasRecursive() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool recursive = 2;
hasRecursive() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool recursive = 1;
hasRecursive() - Method in class alluxio.grpc.DeletePOptions
optional bool recursive = 1;
hasRecursive() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool recursive = 1;
hasRecursive() - Method in class alluxio.grpc.FreePOptions.Builder
optional bool recursive = 1;
hasRecursive() - Method in class alluxio.grpc.FreePOptions
optional bool recursive = 1;
hasRecursive() - Method in interface alluxio.grpc.FreePOptionsOrBuilder
optional bool recursive = 1;
hasRecursive() - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional bool recursive = 4;
hasRecursive() - Method in class alluxio.grpc.ListStatusPOptions
optional bool recursive = 4;
hasRecursive() - Method in interface alluxio.grpc.ListStatusPOptionsOrBuilder
optional bool recursive = 4;
hasRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
whether to load metadata recursively
hasRecursive() - Method in class alluxio.grpc.LoadMetadataPOptions
whether to load metadata recursively
hasRecursive() - Method in interface alluxio.grpc.LoadMetadataPOptionsOrBuilder
whether to load metadata recursively
hasRecursive() - Method in class alluxio.grpc.SetAclPOptions.Builder
optional bool recursive = 2;
hasRecursive() - Method in class alluxio.grpc.SetAclPOptions
optional bool recursive = 2;
hasRecursive() - Method in interface alluxio.grpc.SetAclPOptionsOrBuilder
optional bool recursive = 2;
hasRecursive() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool recursive = 6;
hasRecursive() - Method in class alluxio.grpc.SetAttributePOptions
optional bool recursive = 6;
hasRecursive() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional bool recursive = 6;
hasRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, we now write one journal entry per inode removed
hasRecursive() - Method in class alluxio.proto.journal.File.DeleteFileEntry
Deprecated, we now write one journal entry per inode removed
hasRecursive() - Method in interface alluxio.proto.journal.File.DeleteFileEntryOrBuilder
Deprecated, we now write one journal entry per inode removed
hasRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional bool recursive = 5;
hasRecursive() - Method in class alluxio.proto.journal.File.SetAclEntry
optional bool recursive = 5;
hasRecursive() - Method in interface alluxio.proto.journal.File.SetAclEntryOrBuilder
optional bool recursive = 5;
hasRegisterCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
hasRegisterCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
hasRegisterCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
hasRegisterLease(long) - Method in interface alluxio.master.block.BlockMaster
Verifies if the worker currently holds a RegisterLease.
hasRegisterLease(long) - Method in class alluxio.master.block.DefaultBlockMaster
 
hasRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
hasRemovePathProperties() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
hasRemovePathProperties() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
hasRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
hasRemoveSyncPoint() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
hasRemoveSyncPoint() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
hasRename() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
hasRename() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.RenameEntry rename = 19;
hasRename() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.RenameEntry rename = 19;
hasReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationDurable = 6;
hasReplicationDurable() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 replicationDurable = 6;
hasReplicationDurable() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 replicationDurable = 6;
hasReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_durable = 24;
hasReplicationDurable() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 replication_durable = 24;
hasReplicationDurable() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 replication_durable = 24;
hasReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_durable = 20;
hasReplicationDurable() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int32 replication_durable = 20;
hasReplicationDurable() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int32 replication_durable = 20;
hasReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMax = 4;
hasReplicationMax() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 replicationMax = 4;
hasReplicationMax() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 replicationMax = 4;
hasReplicationMax() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMax = 29;
hasReplicationMax() - Method in class alluxio.grpc.FileInfo
optional int32 replicationMax = 29;
hasReplicationMax() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 replicationMax = 29;
hasReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMax = 7;
hasReplicationMax() - Method in class alluxio.grpc.SetAttributePOptions
optional int32 replicationMax = 7;
hasReplicationMax() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional int32 replicationMax = 7;
hasReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_max = 20;
hasReplicationMax() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 replication_max = 20;
hasReplicationMax() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 replication_max = 20;
hasReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_max = 13;
hasReplicationMax() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 replication_max = 13;
hasReplicationMax() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 replication_max = 13;
hasReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_max = 8;
hasReplicationMax() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int32 replication_max = 8;
hasReplicationMax() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int32 replication_max = 8;
hasReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_max = 21;
hasReplicationMax() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int32 replication_max = 21;
hasReplicationMax() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int32 replication_max = 21;
hasReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMin = 5;
hasReplicationMin() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 replicationMin = 5;
hasReplicationMin() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 replicationMin = 5;
hasReplicationMin() - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMin = 30;
hasReplicationMin() - Method in class alluxio.grpc.FileInfo
optional int32 replicationMin = 30;
hasReplicationMin() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int32 replicationMin = 30;
hasReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMin = 8;
hasReplicationMin() - Method in class alluxio.grpc.SetAttributePOptions
optional int32 replicationMin = 8;
hasReplicationMin() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional int32 replicationMin = 8;
hasReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_min = 21;
hasReplicationMin() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int32 replication_min = 21;
hasReplicationMin() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int32 replication_min = 21;
hasReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_min = 14;
hasReplicationMin() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int32 replication_min = 14;
hasReplicationMin() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int32 replication_min = 14;
hasReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_min = 9;
hasReplicationMin() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional int32 replication_min = 9;
hasReplicationMin() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional int32 replication_min = 9;
hasReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_min = 22;
hasReplicationMin() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int32 replication_min = 22;
hasReplicationMin() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int32 replication_min = 22;
hasReport() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
hasReport() - Method in class alluxio.grpc.GetConfigReportPResponse
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
hasReport() - Method in interface alluxio.grpc.GetConfigReportPResponseOrBuilder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
hasRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
optional bytes request_body = 1;
hasRequestBody() - Method in class alluxio.grpc.SubmitJobPRequest
optional bytes request_body = 1;
hasRequestBody() - Method in interface alluxio.grpc.SubmitJobPRequestOrBuilder
optional bytes request_body = 1;
hasRequestHeader() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
hasRequestHeader() - Method in class alluxio.grpc.TransportMessage
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
hasRequestHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
hasRequestId() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
optional int64 requestId = 1;
hasRequestId() - Method in class alluxio.grpc.MessagingRequestHeader
optional int64 requestId = 1;
hasRequestId() - Method in interface alluxio.grpc.MessagingRequestHeaderOrBuilder
optional int64 requestId = 1;
hasRequestId() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional int64 requestId = 1;
hasRequestId() - Method in class alluxio.grpc.MessagingResponseHeader
optional int64 requestId = 1;
hasRequestId() - Method in interface alluxio.grpc.MessagingResponseHeaderOrBuilder
optional int64 requestId = 1;
hasResponseHeader() - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
hasResponseHeader() - Method in class alluxio.grpc.TransportMessage
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
hasResponseHeader() - Method in interface alluxio.grpc.TransportMessageOrBuilder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
hasResult() - Method in class alluxio.grpc.JobInfo.Builder
optional bytes result = 9;
hasResult() - Method in class alluxio.grpc.JobInfo
optional bytes result = 9;
hasResult() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional bytes result = 9;
hasRetryable() - Method in class alluxio.grpc.BlockStatus.Builder
optional bool retryable = 4;
hasRetryable() - Method in class alluxio.grpc.BlockStatus
optional bool retryable = 4;
hasRetryable() - Method in interface alluxio.grpc.BlockStatusOrBuilder
optional bool retryable = 4;
hasRetryable() - Method in class alluxio.grpc.FileFailure.Builder
optional bool retryable = 4;
hasRetryable() - Method in class alluxio.grpc.FileFailure
optional bool retryable = 4;
hasRetryable() - Method in interface alluxio.grpc.FileFailureOrBuilder
optional bool retryable = 4;
hasRetryable() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional bool retryable = 4;
hasRetryable() - Method in class alluxio.grpc.LoadFileFailure
optional bool retryable = 4;
hasRetryable() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
optional bool retryable = 4;
hasRetryable() - Method in class alluxio.grpc.RouteFailure.Builder
optional bool retryable = 4;
hasRetryable() - Method in class alluxio.grpc.RouteFailure
optional bool retryable = 4;
hasRetryable() - Method in interface alluxio.grpc.RouteFailureOrBuilder
optional bool retryable = 4;
hasRevision() - Method in class alluxio.grpc.BuildVersion.Builder
the git revision at the time of building
hasRevision() - Method in class alluxio.grpc.BuildVersion
the git revision at the time of building
hasRevision() - Method in interface alluxio.grpc.BuildVersionOrBuilder
the git revision at the time of building
hasRevision() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string revision = 5;
hasRevision() - Method in class alluxio.grpc.RegisterMasterPOptions
optional string revision = 5;
hasRevision() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional string revision = 5;
hasRoute() - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
hasRoute() - Method in class alluxio.grpc.RouteFailure
required .alluxio.grpc.block.Route route = 1;
hasRoute() - Method in interface alluxio.grpc.RouteFailureOrBuilder
required .alluxio.grpc.block.Route route = 1;
hasRpcPort() - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 rpcPort = 3;
hasRpcPort() - Method in class alluxio.grpc.MasterInfo
optional int32 rpcPort = 3;
hasRpcPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int32 rpcPort = 3;
hasRpcPort() - Method in class alluxio.grpc.NetAddress.Builder
optional int32 rpcPort = 2;
hasRpcPort() - Method in class alluxio.grpc.NetAddress
optional int32 rpcPort = 2;
hasRpcPort() - Method in interface alluxio.grpc.NetAddressOrBuilder
optional int32 rpcPort = 2;
hasRpcPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 rpcPort = 2;
hasRpcPort() - Method in class alluxio.grpc.WorkerNetAddress
optional int32 rpcPort = 2;
hasRpcPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional int32 rpcPort = 2;
hasRunAsync() - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool runAsync = 2;
hasRunAsync() - Method in class alluxio.grpc.BackupPOptions
optional bool runAsync = 2;
hasRunAsync() - Method in interface alluxio.grpc.BackupPOptionsOrBuilder
optional bool runAsync = 2;
hasRunTaskCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
hasRunTaskCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
hasRunTaskCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
hasS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
hasS3SyntaxOptions() - Method in class alluxio.grpc.RenamePOptions
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
hasS3SyntaxOptions() - Method in interface alluxio.grpc.RenamePOptionsOrBuilder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
hasSafeMode() - Method in class alluxio.grpc.MasterInfo.Builder
optional bool safeMode = 4;
hasSafeMode() - Method in class alluxio.grpc.MasterInfo
optional bool safeMode = 4;
hasSafeMode() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional bool safeMode = 4;
hasSameLock(LockResource) - Method in class alluxio.resource.LockResource
Returns true if the other LockResource contains the same lock.
hasScale() - Method in class alluxio.grpc.table.Decimal.Builder
force using scale first in Decimal.compareTo
hasScale() - Method in class alluxio.grpc.table.Decimal
force using scale first in Decimal.compareTo
hasScale() - Method in interface alluxio.grpc.table.DecimalOrBuilder
force using scale first in Decimal.compareTo
hasScanCompleted() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanCompleted = 4;
hasScanCompleted() - Method in class alluxio.grpc.PolicyStatus
optional int64 scanCompleted = 4;
hasScanCompleted() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 scanCompleted = 4;
hasScanPendingAction() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanPendingAction = 3;
hasScanPendingAction() - Method in class alluxio.grpc.PolicyStatus
optional int64 scanPendingAction = 3;
hasScanPendingAction() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 scanPendingAction = 3;
hasScanStartedMs() - Method in class alluxio.grpc.PolicyStatus.Builder
scan status
hasScanStartedMs() - Method in class alluxio.grpc.PolicyStatus
scan status
hasScanStartedMs() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
scan status
hasScanTotal() - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanTotal = 2;
hasScanTotal() - Method in class alluxio.grpc.PolicyStatus
optional int64 scanTotal = 2;
hasScanTotal() - Method in interface alluxio.grpc.PolicyStatusOrBuilder
optional int64 scanTotal = 2;
hasSchema() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
hasSchema() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.Schema schema = 5;
hasSchema() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.Schema schema = 5;
hasScheme() - Method in class alluxio.AlluxioURI
Tells if this AlluxioURI has scheme or not.
hasSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 sequence_number = 2;
hasSequenceNumber() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
optional int64 sequence_number = 2;
hasSequenceNumber() - Method in interface alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntryOrBuilder
optional int64 sequence_number = 2;
hasSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
shared fields.
hasSequenceNumber() - Method in class alluxio.proto.journal.Journal.JournalEntry
shared fields.
hasSequenceNumber() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
shared fields.
hasSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string serde = 1;
hasSerde() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
optional string serde = 1;
hasSerde() - Method in interface alluxio.grpc.table.layout.hive.StorageFormatOrBuilder
optional string serde = 1;
hasServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
hasServerAddress() - Method in class alluxio.grpc.AddQuorumServerRequest
optional .alluxio.grpc.NetAddress serverAddress = 1;
hasServerAddress() - Method in interface alluxio.grpc.AddQuorumServerRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 1;
hasServerAddress() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
hasServerAddress() - Method in class alluxio.grpc.QuorumServerInfo
optional .alluxio.grpc.NetAddress serverAddress = 1;
hasServerAddress() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 1;
hasServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
hasServerAddress() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
optional .alluxio.grpc.NetAddress serverAddress = 2;
hasServerAddress() - Method in interface alluxio.grpc.RemoveQuorumServerPRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 2;
hasServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
hasServerAddress() - Method in class alluxio.grpc.TransferLeadershipPRequest
optional .alluxio.grpc.NetAddress serverAddress = 2;
hasServerAddress() - Method in interface alluxio.grpc.TransferLeadershipPRequestOrBuilder
optional .alluxio.grpc.NetAddress serverAddress = 2;
hasServerState() - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
hasServerState() - Method in class alluxio.grpc.QuorumServerInfo
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
hasServerState() - Method in interface alluxio.grpc.QuorumServerInfoOrBuilder
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
hasServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
hasServiceType() - Method in class alluxio.grpc.GetServiceVersionPRequest
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
hasServiceType() - Method in interface alluxio.grpc.GetServiceVersionPRequestOrBuilder
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
hasSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
hasSetAcl() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
hasSetAcl() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
hasSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
hasSetAttribute() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
hasSetAttribute() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
hasSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
hasSetTaskPoolSizeCommand() - Method in class alluxio.grpc.JobCommand
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
hasSetTaskPoolSizeCommand() - Method in interface alluxio.grpc.JobCommandOrBuilder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
hasShared() - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool shared = 7;
hasShared() - Method in class alluxio.grpc.MountPointInfo
optional bool shared = 7;
hasShared() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional bool shared = 7;
hasShared() - Method in class alluxio.grpc.MountPOptions.Builder
optional bool shared = 3;
hasShared() - Method in class alluxio.grpc.MountPOptions
optional bool shared = 3;
hasShared() - Method in interface alluxio.grpc.MountPOptionsOrBuilder
optional bool shared = 3;
hasShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
hasShared() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional bool shared = 5;
hasShared() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional bool shared = 5;
hasShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 should_persist_time = 27;
hasShouldPersistTime() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 should_persist_time = 27;
hasShouldPersistTime() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 should_persist_time = 27;
hasShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 should_persist_time = 28;
hasShouldPersistTime() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 should_persist_time = 28;
hasShouldPersistTime() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 should_persist_time = 28;
hasSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional bool skewed = 4;
hasSkewed() - Method in class alluxio.grpc.table.layout.hive.Storage
optional bool skewed = 4;
hasSkewed() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional bool skewed = 4;
hasSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest.Builder
optional bool skip_if_exists = 4;
hasSkipIfExists() - Method in class alluxio.grpc.LoadFileRequest
optional bool skip_if_exists = 4;
hasSkipIfExists() - Method in interface alluxio.grpc.LoadFileRequestOrBuilder
optional bool skip_if_exists = 4;
hasSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool skipIfExists = 5;
hasSkipIfExists() - Method in class alluxio.grpc.LoadJobPOptions
optional bool skipIfExists = 5;
hasSkipIfExists() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool skipIfExists = 5;
hasSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool skip_if_exists = 10;
hasSkipIfExists() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional bool skip_if_exists = 10;
hasSkipIfExists() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional bool skip_if_exists = 10;
hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotIndex = 2;
hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotData
optional int64 snapshotIndex = 2;
hasSnapshotIndex() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
optional int64 snapshotIndex = 2;
hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotIndex = 2;
hasSnapshotIndex() - Method in class alluxio.grpc.SnapshotMetadata
optional int64 snapshotIndex = 2;
hasSnapshotIndex() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
optional int64 snapshotIndex = 2;
hasSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated. 
hasSnapshotInfo() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated. 
hasSnapshotInfo() - Method in interface alluxio.grpc.GetSnapshotInfoRequestOrBuilder
Deprecated. 
hasSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated. 
hasSnapshotInfoRequest() - Method in class alluxio.grpc.JournalQueryRequest
Deprecated. 
hasSnapshotInfoRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
Deprecated. 
hasSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated. 
hasSnapshotInfoResponse() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated. 
hasSnapshotInfoResponse() - Method in interface alluxio.grpc.JournalQueryResponseOrBuilder
Deprecated. 
hasSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated. 
hasSnapshotRequest() - Method in class alluxio.grpc.JournalQueryRequest
Deprecated. 
hasSnapshotRequest() - Method in interface alluxio.grpc.JournalQueryRequestOrBuilder
Deprecated. 
hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotTerm = 1;
hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotData
optional int64 snapshotTerm = 1;
hasSnapshotTerm() - Method in interface alluxio.grpc.SnapshotDataOrBuilder
optional int64 snapshotTerm = 1;
hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotTerm = 1;
hasSnapshotTerm() - Method in class alluxio.grpc.SnapshotMetadata
optional int64 snapshotTerm = 1;
hasSnapshotTerm() - Method in interface alluxio.grpc.SnapshotMetadataOrBuilder
optional int64 snapshotTerm = 1;
hasSource() - Method in class alluxio.grpc.ClientMetrics.Builder
optional string source = 1;
hasSource() - Method in class alluxio.grpc.ClientMetrics
optional string source = 1;
hasSource() - Method in interface alluxio.grpc.ClientMetricsOrBuilder
optional string source = 1;
hasSource() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string source = 2;
hasSource() - Method in class alluxio.grpc.ConfigProperty
optional string source = 2;
hasSource() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string source = 2;
hasSource() - Method in class alluxio.grpc.Metric.Builder
optional string source = 2;
hasSource() - Method in class alluxio.grpc.Metric
optional string source = 2;
hasSource() - Method in interface alluxio.grpc.MetricOrBuilder
optional string source = 2;
hasSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in class alluxio.grpc.AsyncCacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in class alluxio.grpc.CacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in class alluxio.grpc.CacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in interface alluxio.grpc.CacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourceHost() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
TODO(calvin): source host and port should be replace with WorkerNetAddress
hasSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int32 source_port = 3;
hasSourcePort() - Method in class alluxio.grpc.AsyncCacheRequest
optional int32 source_port = 3;
hasSourcePort() - Method in interface alluxio.grpc.AsyncCacheRequestOrBuilder
optional int32 source_port = 3;
hasSourcePort() - Method in class alluxio.grpc.CacheRequest.Builder
optional int32 source_port = 3;
hasSourcePort() - Method in class alluxio.grpc.CacheRequest
optional int32 source_port = 3;
hasSourcePort() - Method in interface alluxio.grpc.CacheRequestOrBuilder
optional int32 source_port = 3;
hasSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
hasSourcePort() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
optional int32 source_port = 3;
hasSourcePort() - Method in interface alluxio.proto.dataserver.Protocol.AsyncCacheRequestOrBuilder
optional int32 source_port = 3;
hasSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 space_to_reserve = 10;
hasSpaceToReserve() - Method in class alluxio.grpc.WriteRequestCommand
optional int64 space_to_reserve = 10;
hasSpaceToReserve() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional int64 space_to_reserve = 10;
hasSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
hasSpaceToReserve() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int64 space_to_reserve = 4;
hasSpaceToReserve() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int64 space_to_reserve = 4;
hasSpec() - Method in class alluxio.grpc.table.LayoutSpec.Builder
optional string spec = 1;
hasSpec() - Method in class alluxio.grpc.table.LayoutSpec
optional string spec = 1;
hasSpec() - Method in interface alluxio.grpc.table.LayoutSpecOrBuilder
optional string spec = 1;
hasSpec() - Method in class alluxio.grpc.table.PartitionSpec.Builder
optional string spec = 1;
hasSpec() - Method in class alluxio.grpc.table.PartitionSpec
optional string spec = 1;
hasSpec() - Method in interface alluxio.grpc.table.PartitionSpecOrBuilder
optional string spec = 1;
hasSrc() - Method in class alluxio.grpc.Route.Builder
required string src = 1;
hasSrc() - Method in class alluxio.grpc.Route
required string src = 1;
hasSrc() - Method in interface alluxio.grpc.RouteOrBuilder
required string src = 1;
hasSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string src = 1;
hasSrc() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required string src = 1;
hasSrc() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required string src = 1;
hasSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string src = 1;
hasSrc() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required string src = 1;
hasSrc() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required string src = 1;
hasSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string srcPath = 2;
hasSrcPath() - Method in class alluxio.grpc.AddPolicyPOptions
optional string srcPath = 2;
hasSrcPath() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string srcPath = 2;
hasStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start the listing after this path.
hasStartAfter() - Method in class alluxio.grpc.ListStatusPartialPOptions
Start the listing after this path.
hasStartAfter() - Method in interface alluxio.grpc.ListStatusPartialPOptionsOrBuilder
Start the listing after this path.
hasStartTime() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional int64 startTime = 3;
hasStartTime() - Method in class alluxio.grpc.JobMasterStatus
optional int64 startTime = 3;
hasStartTime() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional int64 startTime = 3;
hasStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional int64 startTime = 2;
hasStartTime() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional int64 startTime = 2;
hasStartTime() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional int64 startTime = 2;
hasStartTime() - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 startTime = 3;
hasStartTime() - Method in class alluxio.grpc.ProxyStatus
optional int64 startTime = 3;
hasStartTime() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional int64 startTime = 3;
hasStartTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 startTimeMs = 5;
hasStartTimeMs() - Method in class alluxio.grpc.MasterInfo
optional int64 startTimeMs = 5;
hasStartTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int64 startTimeMs = 5;
hasStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 startTimeMs = 2;
hasStartTimeMs() - Method in class alluxio.grpc.RegisterJobMasterPOptions
optional int64 startTimeMs = 2;
hasStartTimeMs() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
optional int64 startTimeMs = 2;
hasStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 startTimeMs = 2;
hasStartTimeMs() - Method in class alluxio.grpc.RegisterMasterPOptions
optional int64 startTimeMs = 2;
hasStartTimeMs() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional int64 startTimeMs = 2;
hasStartTimeMs() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 startTimeMs = 7;
hasStartTimeMs() - Method in class alluxio.grpc.WorkerInfo
optional int64 startTimeMs = 7;
hasStartTimeMs() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 startTimeMs = 7;
hasState() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional string state = 1;
hasState() - Method in class alluxio.grpc.JobMasterStatus
optional string state = 1;
hasState() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional string state = 1;
hasState() - Method in class alluxio.grpc.MasterVersion.Builder
optional string state = 3;
hasState() - Method in class alluxio.grpc.MasterVersion
optional string state = 3;
hasState() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional string state = 3;
hasState() - Method in class alluxio.grpc.ProxyStatus.Builder
optional string state = 2;
hasState() - Method in class alluxio.grpc.ProxyStatus
optional string state = 2;
hasState() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional string state = 2;
hasState() - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
hasState() - Method in class alluxio.grpc.WorkerInfo
optional string state = 4;
hasState() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional string state = 4;
hasState() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
hasState() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required .alluxio.proto.journal.PJobState state = 3;
hasState() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required .alluxio.proto.journal.PJobState state = 3;
hasState() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 2;
hasState() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required .alluxio.proto.journal.PJobState state = 2;
hasState() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required .alluxio.proto.journal.PJobState state = 2;
hasState() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
hasState() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required .alluxio.proto.journal.PJobState state = 3;
hasState() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required .alluxio.proto.journal.PJobState state = 3;
hasStatus() - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.Status status = 4;
hasStatus() - Method in class alluxio.grpc.CmdSummary
optional .alluxio.grpc.job.Status status = 4;
hasStatus() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional .alluxio.grpc.job.Status status = 4;
hasStatus() - Method in class alluxio.grpc.ConfigCheckReport.Builder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
hasStatus() - Method in class alluxio.grpc.ConfigCheckReport
optional .alluxio.grpc.meta.ConfigStatus status = 3;
hasStatus() - Method in interface alluxio.grpc.ConfigCheckReportOrBuilder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
hasStatus() - Method in class alluxio.grpc.CopyResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.CopyResponse
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in interface alluxio.grpc.CopyResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
hasStatus() - Method in class alluxio.grpc.GetPolicyStatusPResponse
optional .alluxio.grpc.policy.PolicyStatus status = 1;
hasStatus() - Method in interface alluxio.grpc.GetPolicyStatusPResponseOrBuilder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
hasStatus() - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.Status status = 4;
hasStatus() - Method in class alluxio.grpc.JobInfo
optional .alluxio.grpc.job.Status status = 4;
hasStatus() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional .alluxio.grpc.job.Status status = 4;
hasStatus() - Method in class alluxio.grpc.JobProgress.Builder
optional .alluxio.grpc.job.Status status = 7;
hasStatus() - Method in class alluxio.grpc.JobProgress
optional .alluxio.grpc.job.Status status = 7;
hasStatus() - Method in interface alluxio.grpc.JobProgressOrBuilder
optional .alluxio.grpc.job.Status status = 7;
hasStatus() - Method in class alluxio.grpc.LoadFileResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.LoadFileResponse
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in interface alluxio.grpc.LoadFileResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.LoadResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.LoadResponse
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in interface alluxio.grpc.LoadResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.MoveResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.MoveResponse
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in interface alluxio.grpc.MoveResponseOrBuilder
required .alluxio.grpc.block.TaskStatus status = 1;
hasStatus() - Method in class alluxio.grpc.StatusSummary.Builder
optional .alluxio.grpc.job.Status status = 1;
hasStatus() - Method in class alluxio.grpc.StatusSummary
optional .alluxio.grpc.job.Status status = 1;
hasStatus() - Method in interface alluxio.grpc.StatusSummaryOrBuilder
optional .alluxio.grpc.job.Status status = 1;
hasStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
hasStatus() - Method in class alluxio.grpc.table.SyncDatabasePResponse
optional .alluxio.grpc.table.SyncStatus status = 2;
hasStatus() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
optional .alluxio.grpc.table.SyncStatus status = 2;
hasStatus() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
hasStatus() - Method in class alluxio.proto.dataserver.Protocol.Response
optional .alluxio.proto.status.PStatus status = 1;
hasStatus() - Method in interface alluxio.proto.dataserver.Protocol.ResponseOrBuilder
optional .alluxio.proto.status.PStatus status = 1;
hasStatus(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
Check if a status has been loaded in the cache for the given AlluxioURI.
hasStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
hasStorage() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional .alluxio.grpc.table.layout.Storage storage = 5;
hasStorage() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional .alluxio.grpc.table.layout.Storage storage = 5;
hasStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
hasStorageFormat() - Method in class alluxio.grpc.table.layout.hive.Storage
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
hasStorageFormat() - Method in interface alluxio.grpc.table.layout.hive.StorageOrBuilder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
hasStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
hasStringStats() - Method in class alluxio.grpc.table.ColumnStatisticsData
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
hasStringStats() - Method in interface alluxio.grpc.table.ColumnStatisticsDataOrBuilder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
hasStringType() - Method in class alluxio.grpc.table.Value.Builder
string string_type = 3;
hasStringType() - Method in class alluxio.grpc.table.Value
string string_type = 3;
hasStringType() - Method in interface alluxio.grpc.table.ValueOrBuilder
string string_type = 3;
hasStringValue() - Method in class alluxio.grpc.MetricValue.Builder
optional string stringValue = 2;
hasStringValue() - Method in class alluxio.grpc.MetricValue
optional string stringValue = 2;
hasStringValue() - Method in interface alluxio.grpc.MetricValueOrBuilder
optional string stringValue = 2;
hasSubCommand() - Method in interface alluxio.cli.Command
If a command has sub-commands, the first argument should be the sub-command's name, all arguments and options will be parsed for the sub-command.
hasSubject() - Method in class alluxio.grpc.PAclEntry.Builder
optional string subject = 2;
hasSubject() - Method in class alluxio.grpc.PAclEntry
optional string subject = 2;
hasSubject() - Method in interface alluxio.grpc.PAclEntryOrBuilder
optional string subject = 2;
hasSubject() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional string subject = 2;
hasSubject() - Method in class alluxio.proto.shared.Acl.AclEntry
optional string subject = 2;
hasSubject() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
optional string subject = 2;
hasSubmissionTime() - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 submissionTime = 5;
hasSubmissionTime() - Method in class alluxio.grpc.CmdSummary
optional int64 submissionTime = 5;
hasSubmissionTime() - Method in interface alluxio.grpc.CmdSummaryOrBuilder
optional int64 submissionTime = 5;
hasSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
TODO(gpang): remove in favor of status
hasSuccess() - Method in class alluxio.grpc.table.AttachDatabasePResponse
TODO(gpang): remove in favor of status
hasSuccess() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
TODO(gpang): remove in favor of status
hasSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
optional bool success = 1;
hasSuccess() - Method in class alluxio.grpc.table.DetachDatabasePResponse
optional bool success = 1;
hasSuccess() - Method in interface alluxio.grpc.table.DetachDatabasePResponseOrBuilder
optional bool success = 1;
hasSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
TODO(gpang): remove in favor of status
hasSuccess() - Method in class alluxio.grpc.table.SyncDatabasePResponse
TODO(gpang): remove in favor of status
hasSuccess() - Method in interface alluxio.grpc.table.SyncDatabasePResponseOrBuilder
TODO(gpang): remove in favor of status
hasSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
hasSummary() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
hasSummary() - Method in interface alluxio.grpc.GetJobServiceSummaryPResponseOrBuilder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
hasSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 syncIntervalMs = 1;
hasSyncIntervalMs() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional int64 syncIntervalMs = 1;
hasSyncIntervalMs() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional int64 syncIntervalMs = 1;
hasSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool syncParentNextTime = 5;
hasSyncParentNextTime() - Method in class alluxio.grpc.DeletePOptions
optional bool syncParentNextTime = 5;
hasSyncParentNextTime() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool syncParentNextTime = 5;
hasSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional string syncpoint_path = 1;
hasSyncpointPath() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
optional string syncpoint_path = 1;
hasSyncpointPath() - Method in interface alluxio.proto.journal.File.AddSyncPointEntryOrBuilder
optional string syncpoint_path = 1;
hasSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional string syncpoint_path = 1;
hasSyncpointPath() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
optional string syncpoint_path = 1;
hasSyncpointPath() - Method in interface alluxio.proto.journal.File.RemoveSyncPointEntryOrBuilder
optional string syncpoint_path = 1;
hasSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
hasSyncStatus() - Method in class alluxio.grpc.table.AttachDatabasePResponse
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
hasSyncStatus() - Method in interface alluxio.grpc.table.AttachDatabasePResponseOrBuilder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
hasTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
hasTableInfo() - Method in class alluxio.grpc.table.GetTablePResponse
optional .alluxio.grpc.table.TableInfo table_info = 1;
hasTableInfo() - Method in interface alluxio.grpc.table.GetTablePResponseOrBuilder
optional .alluxio.grpc.table.TableInfo table_info = 1;
hasTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
optional string table_name = 2;
hasTableName() - Method in interface alluxio.grpc.table.GetPartitionColumnStatisticsPRequestOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
optional string table_name = 2;
hasTableName() - Method in interface alluxio.grpc.table.GetTableColumnStatisticsPRequestOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.GetTablePRequest
optional string table_name = 2;
hasTableName() - Method in interface alluxio.grpc.table.GetTablePRequestOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string table_name = 4;
hasTableName() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
optional string table_name = 4;
hasTableName() - Method in interface alluxio.grpc.table.layout.hive.PartitionInfoOrBuilder
optional string table_name = 4;
hasTableName() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.ReadTablePRequest
optional string table_name = 2;
hasTableName() - Method in interface alluxio.grpc.table.ReadTablePRequestOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.TableInfo.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.TableInfo
optional string table_name = 2;
hasTableName() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.TransformJobInfo
optional string table_name = 2;
hasTableName() - Method in interface alluxio.grpc.table.TransformJobInfoOrBuilder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string table_name = 2;
hasTableName() - Method in class alluxio.grpc.table.TransformTablePRequest
optional string table_name = 2;
hasTableName() - Method in interface alluxio.grpc.table.TransformTablePRequestOrBuilder
optional string table_name = 2;
hasTag() - Method in class alluxio.grpc.UfsReadOptions.Builder
required string tag = 1;
hasTag() - Method in class alluxio.grpc.UfsReadOptions
required string tag = 1;
hasTag() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
required string tag = 1;
hasTargetDirectory() - Method in class alluxio.grpc.BackupPRequest.Builder
optional string targetDirectory = 2;
hasTargetDirectory() - Method in class alluxio.grpc.BackupPRequest
optional string targetDirectory = 2;
hasTargetDirectory() - Method in interface alluxio.grpc.BackupPRequestOrBuilder
optional string targetDirectory = 2;
hasTaskArgs() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes taskArgs = 4;
hasTaskArgs() - Method in class alluxio.grpc.RunTaskCommand
optional bytes taskArgs = 4;
hasTaskArgs() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional bytes taskArgs = 4;
hasTaskId() - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 taskId = 2;
hasTaskId() - Method in class alluxio.grpc.CancelTaskCommand
optional int64 taskId = 2;
hasTaskId() - Method in interface alluxio.grpc.CancelTaskCommandOrBuilder
optional int64 taskId = 2;
hasTaskId() - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 taskId = 2;
hasTaskId() - Method in class alluxio.grpc.RunTaskCommand
optional int64 taskId = 2;
hasTaskId() - Method in interface alluxio.grpc.RunTaskCommandOrBuilder
optional int64 taskId = 2;
hasTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 taskPoolSize = 5;
hasTaskPoolSize() - Method in class alluxio.grpc.JobWorkerHealth
optional int32 taskPoolSize = 5;
hasTaskPoolSize() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int32 taskPoolSize = 5;
hasTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
optional int32 taskPoolSize = 1;
hasTaskPoolSize() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
optional int32 taskPoolSize = 1;
hasTaskPoolSize() - Method in interface alluxio.grpc.SetTaskPoolSizeCommandOrBuilder
optional int32 taskPoolSize = 1;
hasTempBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Checks if the storage has a given temp block.
hasTempBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Checks if a temp block is in this storage dir.
hasTempFile(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
hasTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string temp_ufs_path = 23;
hasTempUfsPath() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string temp_ufs_path = 23;
hasTempUfsPath() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string temp_ufs_path = 23;
hasTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string tempUfsPath = 12;
hasTempUfsPath() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string tempUfsPath = 12;
hasTempUfsPath() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string tempUfsPath = 12;
hasTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string temp_ufs_path = 11;
hasTempUfsPath() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
optional string temp_ufs_path = 11;
hasTempUfsPath() - Method in interface alluxio.proto.journal.File.UpdateInodeFileEntryOrBuilder
optional string temp_ufs_path = 11;
hasTier() - Method in class alluxio.grpc.WriteRequestCommand.Builder
This is only applicable for block write.
hasTier() - Method in class alluxio.grpc.WriteRequestCommand
This is only applicable for block write.
hasTier() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
This is only applicable for block write.
hasTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
hasTier() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
optional int32 tier = 3;
hasTier() - Method in interface alluxio.proto.dataserver.Protocol.LocalBlockCreateRequestOrBuilder
optional int32 tier = 3;
hasTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for block write.
hasTier() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
This is only applicable for block write.
hasTier() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
This is only applicable for block write.
hasTier() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string tier = 2;
hasTier() - Method in class alluxio.proto.meta.Block.BlockLocation
optional string tier = 2;
hasTier() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional string tier = 2;
hasTierAlias() - Method in class alluxio.grpc.BlockLocation.Builder
optional string tierAlias = 3;
hasTierAlias() - Method in class alluxio.grpc.BlockLocation
optional string tierAlias = 3;
hasTierAlias() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional string tierAlias = 3;
hasTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string tierAlias = 1;
hasTierAlias() - Method in class alluxio.grpc.BlockStoreLocationProto
optional string tierAlias = 1;
hasTierAlias() - Method in interface alluxio.grpc.BlockStoreLocationProtoOrBuilder
optional string tierAlias = 1;
hasTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the alias of the target tier
hasTierAlias() - Method in class alluxio.grpc.CommitBlockPRequest
the alias of the target tier
hasTierAlias() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the alias of the target tier
hasTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string timeExpression = 4;
hasTimeExpression() - Method in class alluxio.grpc.AddPolicyPOptions
optional string timeExpression = 4;
hasTimeExpression() - Method in interface alluxio.grpc.AddPolicyPOptionsOrBuilder
optional string timeExpression = 4;
hasTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
required string transferId = 1;
hasTransferId() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
required string transferId = 1;
hasTransferId() - Method in interface alluxio.grpc.GetTransferLeaderMessagePRequestOrBuilder
required string transferId = 1;
hasTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
required string transferId = 1;
hasTransferId() - Method in class alluxio.grpc.TransferLeadershipPResponse
required string transferId = 1;
hasTransferId() - Method in interface alluxio.grpc.TransferLeadershipPResponseOrBuilder
required string transferId = 1;
hasTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
hasTransMsg() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
hasTransMsg() - Method in interface alluxio.grpc.GetTransferLeaderMessagePResponseOrBuilder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
hasTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
the timestamp in nanoseconds when this FileStatus is refreshed
hasTs() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
the timestamp in nanoseconds when this FileStatus is refreshed
hasTs() - Method in interface alluxio.proto.meta.DoraMeta.FileStatusOrBuilder
the timestamp in nanoseconds when this FileStatus is refreshed
hasTtl() - Method in class alluxio.grpc.FileInfo.Builder
optional int64 ttl = 15;
hasTtl() - Method in class alluxio.grpc.FileInfo
optional int64 ttl = 15;
hasTtl() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional int64 ttl = 15;
hasTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 ttl = 2;
hasTtl() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional int64 ttl = 2;
hasTtl() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional int64 ttl = 2;
hasTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional int64 ttl = 13;
hasTtl() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional int64 ttl = 13;
hasTtl() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional int64 ttl = 13;
hasTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
hasTtl() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional int64 ttl = 4;
hasTtl() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional int64 ttl = 4;
hasTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 ttl = 12;
hasTtl() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional int64 ttl = 12;
hasTtl() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional int64 ttl = 12;
hasTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 ttl = 4;
hasTtl() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional int64 ttl = 4;
hasTtl() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional int64 ttl = 4;
hasTtlAction() - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.TtlAction ttlAction = 22;
hasTtlAction() - Method in class alluxio.grpc.FileInfo
optional .alluxio.grpc.TtlAction ttlAction = 22;
hasTtlAction() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional .alluxio.grpc.TtlAction ttlAction = 22;
hasTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.TtlAction ttlAction = 3;
hasTtlAction() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
optional .alluxio.grpc.TtlAction ttlAction = 3;
hasTtlAction() - Method in interface alluxio.grpc.FileSystemMasterCommonPOptionsOrBuilder
optional .alluxio.grpc.TtlAction ttlAction = 3;
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.InodeDirectoryEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
hasTtlAction() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
hasTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.grpc.TtlAction ttl_action = 5;
hasTtlAction() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional .alluxio.grpc.TtlAction ttl_action = 5;
hasTtlAction() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional .alluxio.grpc.TtlAction ttl_action = 5;
hasTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 tx_id = 2;
hasTxId() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
optional int64 tx_id = 2;
hasTxId() - Method in interface alluxio.proto.journal.File.ActiveSyncTxIdEntryOrBuilder
optional int64 tx_id = 2;
hasType() - Method in class alluxio.grpc.JobDescription.Builder
required string type = 1;
hasType() - Method in class alluxio.grpc.JobDescription
required string type = 1;
hasType() - Method in interface alluxio.grpc.JobDescriptionOrBuilder
required string type = 1;
hasType() - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.JobType type = 8;
hasType() - Method in class alluxio.grpc.JobInfo
optional .alluxio.grpc.job.JobType type = 8;
hasType() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional .alluxio.grpc.job.JobType type = 8;
hasType() - Method in class alluxio.grpc.PAclEntry.Builder
optional .alluxio.grpc.file.PAclEntryType type = 1;
hasType() - Method in class alluxio.grpc.PAclEntry
optional .alluxio.grpc.file.PAclEntryType type = 1;
hasType() - Method in interface alluxio.grpc.PAclEntryOrBuilder
optional .alluxio.grpc.file.PAclEntryType type = 1;
hasType() - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string type = 3;
hasType() - Method in class alluxio.grpc.table.FieldSchema
optional string type = 3;
hasType() - Method in interface alluxio.grpc.table.FieldSchemaOrBuilder
optional string type = 3;
hasType() - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
hasType() - Method in class alluxio.grpc.table.TableInfo
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
hasType() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
hasType() - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.grpc.block.RequestType type = 1;
hasType() - Method in class alluxio.grpc.WriteRequestCommand
optional .alluxio.grpc.block.RequestType type = 1;
hasType() - Method in interface alluxio.grpc.WriteRequestCommandOrBuilder
optional .alluxio.grpc.block.RequestType type = 1;
hasType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
hasType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
hasType() - Method in interface alluxio.proto.dataserver.Protocol.ReadResponseOrBuilder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
hasType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
hasType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
optional .alluxio.proto.dataserver.RequestType type = 1;
hasType() - Method in interface alluxio.proto.dataserver.Protocol.WriteRequestOrBuilder
optional .alluxio.proto.dataserver.RequestType type = 1;
hasType() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional .alluxio.proto.shared.AclEntryType type = 1;
hasType() - Method in class alluxio.proto.shared.Acl.AclEntry
optional .alluxio.proto.shared.AclEntryType type = 1;
hasType() - Method in interface alluxio.proto.shared.Acl.AclEntryOrBuilder
optional .alluxio.proto.shared.AclEntryType type = 1;
hasUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
hasUdbConnectionUri() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_connection_uri = 2;
hasUdbConnectionUri() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_connection_uri = 2;
hasUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
hasUdbDbName() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_db_name = 3;
hasUdbDbName() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_db_name = 3;
hasUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
hasUdbType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
optional string udb_type = 1;
hasUdbType() - Method in interface alluxio.grpc.table.AttachDatabasePRequestOrBuilder
optional string udb_type = 1;
hasUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsCapacityBytes = 3 [default = -1];
hasUfsCapacityBytes() - Method in class alluxio.grpc.MountPointInfo
optional int64 ufsCapacityBytes = 3 [default = -1];
hasUfsCapacityBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional int64 ufsCapacityBytes = 3 [default = -1];
hasUfsFileStatus() - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
hasUfsFileStatus() - Method in class alluxio.grpc.UfsStatus
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
hasUfsFileStatus() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
hasUfsFingerprint() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsFingerprint = 26;
hasUfsFingerprint() - Method in class alluxio.grpc.FileInfo
optional string ufsFingerprint = 26;
hasUfsFingerprint() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsFingerprint = 26;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.CompleteFileEntry
optional string ufs_fingerprint = 5;
hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.CompleteFileEntryOrBuilder
optional string ufs_fingerprint = 5;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.InodeFileEntry
optional string ufs_fingerprint = 18;
hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.InodeFileEntryOrBuilder
optional string ufs_fingerprint = 18;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.SetAttributeEntry
optional string ufs_fingerprint = 10;
hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.SetAttributeEntryOrBuilder
optional string ufs_fingerprint = 10;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string ufs_fingerprint = 15;
hasUfsFingerprint() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional string ufs_fingerprint = 15;
hasUfsFingerprint() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional string ufs_fingerprint = 15;
hasUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string ufs_fingerprint = 11;
hasUfsFingerprint() - Method in class alluxio.proto.meta.InodeMeta.Inode
optional string ufs_fingerprint = 11;
hasUfsFingerprint() - Method in interface alluxio.proto.meta.InodeMeta.InodeOrBuilder
optional string ufs_fingerprint = 11;
hasUfsFullPath() - Method in class alluxio.grpc.UfsStatus.Builder
optional string ufs_full_path = 8;
hasUfsFullPath() - Method in class alluxio.grpc.UfsStatus
optional string ufs_full_path = 8;
hasUfsFullPath() - Method in interface alluxio.grpc.UfsStatusOrBuilder
optional string ufs_full_path = 8;
hasUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
hasUfsInfo() - Method in class alluxio.grpc.GetUfsInfoPResponse
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
hasUfsInfo() - Method in interface alluxio.grpc.GetUfsInfoPResponseOrBuilder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
hasUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional int64 ufsLength = 1;
hasUfsLength() - Method in class alluxio.grpc.CompleteFilePOptions
optional int64 ufsLength = 1;
hasUfsLength() - Method in interface alluxio.grpc.CompleteFilePOptionsOrBuilder
optional int64 ufsLength = 1;
hasUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
hasUfsMode() - Method in class alluxio.grpc.UpdateUfsModePOptions
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
hasUfsMode() - Method in interface alluxio.grpc.UpdateUfsModePOptionsOrBuilder
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
hasUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
hasUfsMode() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
hasUfsMode() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
hasUfsPath() - Method in class alluxio.grpc.Block.Builder
optional string ufs_path = 3;
hasUfsPath() - Method in class alluxio.grpc.Block
optional string ufs_path = 3;
hasUfsPath() - Method in interface alluxio.grpc.BlockOrBuilder
optional string ufs_path = 3;
hasUfsPath() - Method in class alluxio.grpc.File.Builder
optional string ufs_path = 2;
hasUfsPath() - Method in class alluxio.grpc.File
optional string ufs_path = 2;
hasUfsPath() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsPath = 4;
hasUfsPath() - Method in class alluxio.grpc.FileInfo
optional string ufsPath = 4;
hasUfsPath() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsPath = 4;
hasUfsPath() - Method in interface alluxio.grpc.FileOrBuilder
optional string ufs_path = 2;
hasUfsPath() - Method in class alluxio.grpc.MountPRequest.Builder
the path of the under file system
hasUfsPath() - Method in class alluxio.grpc.MountPRequest
the path of the under file system
hasUfsPath() - Method in interface alluxio.grpc.MountPRequestOrBuilder
the path of the under file system
hasUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
the ufs path
hasUfsPath() - Method in class alluxio.grpc.UpdateUfsModePRequest
the ufs path
hasUfsPath() - Method in interface alluxio.grpc.UpdateUfsModePRequestOrBuilder
the ufs path
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
optional string ufs_path = 1;
hasUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.CreateUfsFileOptionsOrBuilder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
optional string ufs_path = 1;
hasUfsPath() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
optional string ufs_path = 1;
hasUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
hasUfsPath() - Method in class alluxio.proto.journal.File.AddMountPointEntry
optional string ufs_path = 2;
hasUfsPath() - Method in interface alluxio.proto.journal.File.AddMountPointEntryOrBuilder
optional string ufs_path = 2;
hasUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
hasUfsPath() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
optional string ufsPath = 1;
hasUfsPath() - Method in interface alluxio.proto.journal.File.UpdateUfsModeEntryOrBuilder
optional string ufsPath = 1;
hasUfsReadOptions() - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
hasUfsReadOptions() - Method in class alluxio.grpc.CopyRequest
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
hasUfsReadOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
hasUfsReadOptions() - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
hasUfsReadOptions() - Method in class alluxio.grpc.MoveRequest
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
hasUfsReadOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
hasUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
hasUfsReadWorkerLocation() - Method in class alluxio.grpc.OpenFilePOptions
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
hasUfsReadWorkerLocation() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
hasUfsStatus() - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
hasUfsStatus() - Method in class alluxio.grpc.LoadFileFailure
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
hasUfsStatus() - Method in interface alluxio.grpc.LoadFileFailureOrBuilder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
hasUfsType() - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsType = 35;
hasUfsType() - Method in class alluxio.grpc.FileInfo
optional string ufsType = 35;
hasUfsType() - Method in interface alluxio.grpc.FileInfoOrBuilder
optional string ufsType = 35;
hasUfsType() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
hasUfsType() - Method in class alluxio.grpc.MountPointInfo
optional string ufsType = 2;
hasUfsType() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional string ufsType = 2;
hasUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
required string ufsUri = 1;
hasUfsUri() - Method in class alluxio.grpc.GetMountIdPRequest
required string ufsUri = 1;
hasUfsUri() - Method in interface alluxio.grpc.GetMountIdPRequestOrBuilder
required string ufsUri = 1;
hasUfsUri() - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsUri = 1;
hasUfsUri() - Method in class alluxio.grpc.MountPointInfo
optional string ufsUri = 1;
hasUfsUri() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional string ufsUri = 1;
hasUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
optional string ufsUri = 1;
hasUfsUri() - Method in class alluxio.grpc.ReverseResolvePRequest
optional string ufsUri = 1;
hasUfsUri() - Method in interface alluxio.grpc.ReverseResolvePRequestOrBuilder
optional string ufsUri = 1;
hasUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsUsedBytes = 4 [default = -1];
hasUfsUsedBytes() - Method in class alluxio.grpc.MountPointInfo
optional int64 ufsUsedBytes = 4 [default = -1];
hasUfsUsedBytes() - Method in interface alluxio.grpc.MountPointInfoOrBuilder
optional int64 ufsUsedBytes = 4 [default = -1];
hasUnchecked() - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool unchecked = 3;
hasUnchecked() - Method in class alluxio.grpc.DeletePOptions
optional bool unchecked = 3;
hasUnchecked() - Method in interface alluxio.grpc.DeletePOptionsOrBuilder
optional bool unchecked = 3;
hasUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 unfinishedTasks = 7;
hasUnfinishedTasks() - Method in class alluxio.grpc.JobWorkerHealth
optional int32 unfinishedTasks = 7;
hasUnfinishedTasks() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int32 unfinishedTasks = 7;
hasUnscaled() - Method in class alluxio.grpc.table.Decimal.Builder
required bytes unscaled = 2;
hasUnscaled() - Method in class alluxio.grpc.table.Decimal
required bytes unscaled = 2;
hasUnscaled() - Method in interface alluxio.grpc.table.DecimalOrBuilder
required bytes unscaled = 2;
hasUnused1() - Method in class alluxio.grpc.JobInfo.Builder
formerly result
hasUnused1() - Method in class alluxio.grpc.JobInfo
formerly result
hasUnused1() - Method in interface alluxio.grpc.JobInfoOrBuilder
formerly result
hasUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
hasUpdateInode() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
hasUpdateInode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
hasUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
hasUpdateInodeDirectory() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
hasUpdateInodeDirectory() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
hasUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
hasUpdateInodeFile() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
hasUpdateInodeFile() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
hasUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional bool updateLastAccessTime = 4 [default = true];
hasUpdateLastAccessTime() - Method in class alluxio.grpc.OpenFilePOptions
optional bool updateLastAccessTime = 4 [default = true];
hasUpdateLastAccessTime() - Method in interface alluxio.grpc.OpenFilePOptionsOrBuilder
optional bool updateLastAccessTime = 4 [default = true];
hasUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool updateTimestamps = 4 [default = true];
hasUpdateTimestamps() - Method in class alluxio.grpc.GetStatusPOptions
optional bool updateTimestamps = 4 [default = true];
hasUpdateTimestamps() - Method in interface alluxio.grpc.GetStatusPOptionsOrBuilder
optional bool updateTimestamps = 4 [default = true];
hasUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
hasUpdateUfsMode() - Method in class alluxio.proto.journal.Journal.JournalEntry
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
hasUpdateUfsMode() - Method in interface alluxio.proto.journal.Journal.JournalEntryOrBuilder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
hasUpTimeMs() - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 upTimeMs = 6;
hasUpTimeMs() - Method in class alluxio.grpc.MasterInfo
optional int64 upTimeMs = 6;
hasUpTimeMs() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int64 upTimeMs = 6;
hasUri() - Method in class alluxio.grpc.UfsInfo.Builder
optional string uri = 1;
hasUri() - Method in class alluxio.grpc.UfsInfo
optional string uri = 1;
hasUri() - Method in interface alluxio.grpc.UfsInfoOrBuilder
optional string uri = 1;
hasUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 usedBytes = 6;
hasUsedBytes() - Method in class alluxio.grpc.BlockMasterInfo
optional int64 usedBytes = 6;
hasUsedBytes() - Method in interface alluxio.grpc.BlockMasterInfoOrBuilder
optional int64 usedBytes = 6;
hasUsedBytes() - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 usedBytes = 6;
hasUsedBytes() - Method in class alluxio.grpc.WorkerInfo
optional int64 usedBytes = 6;
hasUsedBytes() - Method in interface alluxio.grpc.WorkerInfoOrBuilder
optional int64 usedBytes = 6;
hasUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the space used in bytes on the target tier
hasUsedBytesOnTier() - Method in class alluxio.grpc.CommitBlockPRequest
the space used in bytes on the target tier
hasUsedBytesOnTier() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the space used in bytes on the target tier
hasUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool useMultipartUpload = 17;
hasUseMultipartUpload() - Method in class alluxio.grpc.CreateFilePOptions
optional bool useMultipartUpload = 17;
hasUseMultipartUpload() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional bool useMultipartUpload = 17;
hasUser() - Method in class alluxio.grpc.UfsReadOptions.Builder
optional string user = 4;
hasUser() - Method in class alluxio.grpc.UfsReadOptions
optional string user = 4;
hasUser() - Method in interface alluxio.grpc.UfsReadOptionsOrBuilder
optional string user = 4;
hasUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
hasUser() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
The client does not need to set this.
hasUser() - Method in interface alluxio.proto.dataserver.Protocol.OpenUfsBlockOptionsOrBuilder
The client does not need to set this.
hasUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional string user = 6;
hasUser() - Method in class alluxio.proto.journal.Job.CopyJobEntry
optional string user = 6;
hasUser() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
optional string user = 6;
hasUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional string user = 5;
hasUser() - Method in class alluxio.proto.journal.Job.LoadJobEntry
optional string user = 5;
hasUser() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
optional string user = 5;
hasUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional string user = 6;
hasUser() - Method in class alluxio.proto.journal.Job.MoveJobEntry
optional string user = 6;
hasUser() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
optional string user = 6;
hasUuid() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional string uuid = 3;
hasUuid() - Method in class alluxio.grpc.CompleteFilePRequest
optional string uuid = 3;
hasUuid() - Method in interface alluxio.grpc.CompleteFilePRequestOrBuilder
optional string uuid = 3;
hasUuid() - Method in class alluxio.grpc.CreateFilePResponse.Builder
uuid of its open file handle
hasUuid() - Method in class alluxio.grpc.CreateFilePResponse
uuid of its open file handle
hasUuid() - Method in interface alluxio.grpc.CreateFilePResponseOrBuilder
uuid of its open file handle
hasValue() - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
hasValue() - Method in class alluxio.grpc.ConfigProperty
optional string value = 3;
hasValue() - Method in interface alluxio.grpc.ConfigPropertyOrBuilder
optional string value = 3;
hasValue() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
hasValue() - Method in class alluxio.grpc.LocationBlockIdListEntry
optional .alluxio.grpc.block.BlockIdList value = 2;
hasValue() - Method in interface alluxio.grpc.LocationBlockIdListEntryOrBuilder
optional .alluxio.grpc.block.BlockIdList value = 2;
hasValue() - Method in class alluxio.grpc.Metric.Builder
optional double value = 4;
hasValue() - Method in class alluxio.grpc.Metric
optional double value = 4;
hasValue() - Method in interface alluxio.grpc.MetricOrBuilder
optional double value = 4;
hasValue() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
hasValue() - Method in class alluxio.proto.journal.File.StringPairEntry
optional string value = 2;
hasValue() - Method in interface alluxio.proto.journal.File.StringPairEntryOrBuilder
optional string value = 2;
hasValue() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string value = 3;
hasValue() - Method in class alluxio.proto.journal.Job.FileFilter
required string value = 3;
hasValue() - Method in interface alluxio.proto.journal.Job.FileFilterOrBuilder
required string value = 3;
hasVerbose() - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional bool verbose = 2;
hasVerbose() - Method in class alluxio.grpc.JobProgressPOptions
optional bool verbose = 2;
hasVerbose() - Method in interface alluxio.grpc.JobProgressPOptionsOrBuilder
optional bool verbose = 2;
hasVerify() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool verify = 2;
hasVerify() - Method in class alluxio.grpc.CopyJobPOptions
optional bool verify = 2;
hasVerify() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional bool verify = 2;
hasVerify() - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool verify = 2;
hasVerify() - Method in class alluxio.grpc.LoadJobPOptions
optional bool verify = 2;
hasVerify() - Method in interface alluxio.grpc.LoadJobPOptionsOrBuilder
optional bool verify = 2;
hasVerify() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool verify = 2;
hasVerify() - Method in class alluxio.grpc.MoveJobPOptions
optional bool verify = 2;
hasVerify() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional bool verify = 2;
hasVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool verify = 5;
hasVerify() - Method in class alluxio.proto.journal.Job.CopyJobEntry
required bool verify = 5;
hasVerify() - Method in interface alluxio.proto.journal.Job.CopyJobEntryOrBuilder
required bool verify = 5;
hasVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool verify = 4;
hasVerify() - Method in class alluxio.proto.journal.Job.LoadJobEntry
required bool verify = 4;
hasVerify() - Method in interface alluxio.proto.journal.Job.LoadJobEntryOrBuilder
required bool verify = 4;
hasVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool verify = 5;
hasVerify() - Method in class alluxio.proto.journal.Job.MoveJobEntry
required bool verify = 5;
hasVerify() - Method in interface alluxio.proto.journal.Job.MoveJobEntryOrBuilder
required bool verify = 5;
hasVersion() - Method in class alluxio.grpc.BuildVersion.Builder
the project version
hasVersion() - Method in class alluxio.grpc.BuildVersion
the project version
hasVersion() - Method in interface alluxio.grpc.BuildVersionOrBuilder
the project version
hasVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
optional int64 version = 1;
hasVersion() - Method in class alluxio.grpc.GetServiceVersionPResponse
optional int64 version = 1;
hasVersion() - Method in interface alluxio.grpc.GetServiceVersionPResponseOrBuilder
optional int64 version = 1;
hasVersion() - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
hasVersion() - Method in class alluxio.grpc.JobMasterStatus
optional .alluxio.grpc.BuildVersion version = 4;
hasVersion() - Method in interface alluxio.grpc.JobMasterStatusOrBuilder
optional .alluxio.grpc.BuildVersion version = 4;
hasVersion() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
hasVersion() - Method in class alluxio.grpc.JobWorkerHealth
optional .alluxio.grpc.BuildVersion version = 8;
hasVersion() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional .alluxio.grpc.BuildVersion version = 8;
hasVersion() - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
hasVersion() - Method in class alluxio.grpc.MasterInfo
optional string version = 7;
hasVersion() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional string version = 7;
hasVersion() - Method in class alluxio.grpc.MasterVersion.Builder
optional string version = 2;
hasVersion() - Method in class alluxio.grpc.MasterVersion
optional string version = 2;
hasVersion() - Method in interface alluxio.grpc.MasterVersionOrBuilder
optional string version = 2;
hasVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
hasVersion() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
optional .alluxio.grpc.BuildVersion version = 3;
hasVersion() - Method in interface alluxio.grpc.ProxyHeartbeatPOptionsOrBuilder
optional .alluxio.grpc.BuildVersion version = 3;
hasVersion() - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
hasVersion() - Method in class alluxio.grpc.ProxyStatus
optional .alluxio.grpc.BuildVersion version = 5;
hasVersion() - Method in interface alluxio.grpc.ProxyStatusOrBuilder
optional .alluxio.grpc.BuildVersion version = 5;
hasVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
hasVersion() - Method in class alluxio.grpc.RegisterJobMasterPOptions
optional .alluxio.grpc.BuildVersion version = 4;
hasVersion() - Method in interface alluxio.grpc.RegisterJobMasterPOptionsOrBuilder
optional .alluxio.grpc.BuildVersion version = 4;
hasVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
hasVersion() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.BuildVersion version = 3;
hasVersion() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.BuildVersion version = 3;
hasVersion() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string version = 4;
hasVersion() - Method in class alluxio.grpc.RegisterMasterPOptions
optional string version = 4;
hasVersion() - Method in interface alluxio.grpc.RegisterMasterPOptionsOrBuilder
optional string version = 4;
hasVersion() - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version = 4;
hasVersion() - Method in class alluxio.grpc.table.Partition
optional int64 version = 4;
hasVersion() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional int64 version = 4;
hasVersion() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version = 10;
hasVersion() - Method in class alluxio.grpc.table.TableInfo
optional int64 version = 10;
hasVersion() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional int64 version = 10;
hasVersion() - Method in class alluxio.grpc.WorkerIdentity.Builder
version of the definition of the opaque identifier
hasVersion() - Method in class alluxio.grpc.WorkerIdentity
version of the definition of the opaque identifier
hasVersion() - Method in interface alluxio.grpc.WorkerIdentityOrBuilder
version of the definition of the opaque identifier
hasVersionCreationTime() - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version_creation_time = 5;
hasVersionCreationTime() - Method in class alluxio.grpc.table.Partition
optional int64 version_creation_time = 5;
hasVersionCreationTime() - Method in interface alluxio.grpc.table.PartitionOrBuilder
optional int64 version_creation_time = 5;
hasVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version_creation_time = 11;
hasVersionCreationTime() - Method in class alluxio.grpc.table.TableInfo
optional int64 version_creation_time = 11;
hasVersionCreationTime() - Method in interface alluxio.grpc.table.TableInfoOrBuilder
optional int64 version_creation_time = 11;
hasWebPort() - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 webPort = 8;
hasWebPort() - Method in class alluxio.grpc.MasterInfo
optional int32 webPort = 8;
hasWebPort() - Method in interface alluxio.grpc.MasterInfoOrBuilder
optional int32 webPort = 8;
hasWebPort() - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 webPort = 4;
hasWebPort() - Method in class alluxio.grpc.WorkerNetAddress
optional int32 webPort = 4;
hasWebPort() - Method in interface alluxio.grpc.WorkerNetAddressOrBuilder
optional int32 webPort = 4;
hasWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
optional bool white_list = 2;
hasWhiteList() - Method in class alluxio.grpc.table.EquatableValueSet
optional bool white_list = 2;
hasWhiteList() - Method in interface alluxio.grpc.table.EquatableValueSetOrBuilder
optional bool white_list = 2;
hasWindowsDrive(String, boolean) - Static method in class alluxio.AlluxioURI
Checks if the path is a windows path.
hasWorkerAddress() - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
hasWorkerAddress() - Method in class alluxio.grpc.BlockLocation
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
hasWorkerAddress() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
hasWorkerHost() - Method in class alluxio.grpc.JobInfo.Builder
optional string workerHost = 12;
hasWorkerHost() - Method in class alluxio.grpc.JobInfo
optional string workerHost = 12;
hasWorkerHost() - Method in interface alluxio.grpc.JobInfoOrBuilder
optional string workerHost = 12;
hasWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
required string workerHostname = 1;
hasWorkerHostname() - Method in class alluxio.grpc.DecommissionWorkerPOptions
required string workerHostname = 1;
hasWorkerHostname() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
required string workerHostname = 1;
hasWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
required string workerHostname = 1;
hasWorkerHostname() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
required string workerHostname = 1;
hasWorkerHostname() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
required string workerHostname = 1;
hasWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the id of the worker
hasWorkerId() - Method in class alluxio.grpc.BlockHeartbeatPRequest
the id of the worker
hasWorkerId() - Method in interface alluxio.grpc.BlockHeartbeatPRequestOrBuilder
the id of the worker
hasWorkerId() - Method in class alluxio.grpc.BlockLocation.Builder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.BlockLocation
optional int64 workerId = 1;
hasWorkerId() - Method in interface alluxio.grpc.BlockLocationOrBuilder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the worker
hasWorkerId() - Method in class alluxio.grpc.CommitBlockPRequest
the id of the worker
hasWorkerId() - Method in interface alluxio.grpc.CommitBlockPRequestOrBuilder
the id of the worker
hasWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the id of the worker
hasWorkerId() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
the id of the worker
hasWorkerId() - Method in interface alluxio.grpc.FileSystemHeartbeatPRequestOrBuilder
the id of the worker
hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePRequest
optional int64 workerId = 1;
hasWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePRequestOrBuilder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.GetRegisterLeasePResponse
optional int64 workerId = 1;
hasWorkerId() - Method in interface alluxio.grpc.GetRegisterLeasePResponseOrBuilder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.GetWorkerIdPResponse
optional int64 workerId = 1;
hasWorkerId() - Method in interface alluxio.grpc.GetWorkerIdPResponseOrBuilder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.JobWorkerHealth
optional int64 workerId = 1;
hasWorkerId() - Method in interface alluxio.grpc.JobWorkerHealthOrBuilder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
optional int64 workerId = 1;
hasWorkerId() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
optional int64 workerId = 1;
hasWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the id of the worker
hasWorkerId() - Method in class alluxio.grpc.RegisterWorkerPRequest
the id of the worker
hasWorkerId() - Method in interface alluxio.grpc.RegisterWorkerPRequestOrBuilder
the id of the worker
hasWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional int64 worker_id = 1;
hasWorkerId() - Method in class alluxio.proto.meta.Block.BlockLocation
optional int64 worker_id = 1;
hasWorkerId() - Method in interface alluxio.proto.meta.Block.BlockLocationOrBuilder
optional int64 worker_id = 1;
hasWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
hasWorkerLocation() - Method in class alluxio.grpc.CreateFilePOptions
If specified, the data will be written to the certain worker
hasWorkerLocation() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
If specified, the data will be written to the certain worker
hasWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
hasWorkerNetAddress() - Method in class alluxio.grpc.GetWorkerIdPRequest
the worker network address
hasWorkerNetAddress() - Method in interface alluxio.grpc.GetWorkerIdPRequestOrBuilder
the worker network address
hasWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
hasWorkerNetAddress() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
the worker network address
hasWorkerNetAddress() - Method in interface alluxio.grpc.NotifyWorkerIdPRequestOrBuilder
the worker network address
hasWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
hasWorkerNetAddress() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
hasWorkerNetAddress() - Method in interface alluxio.grpc.RegisterJobWorkerPRequestOrBuilder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
hasWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
hasWorkerRange() - Method in class alluxio.grpc.GetWorkerReportPOptions
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
hasWorkerRange() - Method in interface alluxio.grpc.GetWorkerReportPOptionsOrBuilder
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
hasWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional int64 workerWebPort = 2;
hasWorkerWebPort() - Method in class alluxio.grpc.DecommissionWorkerPOptions
optional int64 workerWebPort = 2;
hasWorkerWebPort() - Method in interface alluxio.grpc.DecommissionWorkerPOptionsOrBuilder
optional int64 workerWebPort = 2;
hasWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
optional int64 workerWebPort = 2;
hasWorkerWebPort() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
optional int64 workerWebPort = 2;
hasWorkerWebPort() - Method in interface alluxio.grpc.RemoveDisabledWorkerPOptionsOrBuilder
optional int64 workerWebPort = 2;
hasWriteOptions() - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
hasWriteOptions() - Method in class alluxio.grpc.CopyRequest
required .alluxio.grpc.block.WriteOptions write_options = 3;
hasWriteOptions() - Method in interface alluxio.grpc.CopyRequestOrBuilder
required .alluxio.grpc.block.WriteOptions write_options = 3;
hasWriteOptions() - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
hasWriteOptions() - Method in class alluxio.grpc.MoveRequest
required .alluxio.grpc.block.WriteOptions write_options = 3;
hasWriteOptions() - Method in interface alluxio.grpc.MoveRequestOrBuilder
required .alluxio.grpc.block.WriteOptions write_options = 3;
hasWriteTier() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 writeTier = 7;
hasWriteTier() - Method in class alluxio.grpc.CreateFilePOptions
optional int32 writeTier = 7;
hasWriteTier() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional int32 writeTier = 7;
hasWriteType() - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.CopyJobPOptions
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
hasWriteType() - Method in interface alluxio.grpc.CopyJobPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
hasWriteType() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
hasWriteType() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.MoveJobPOptions
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
hasWriteType() - Method in interface alluxio.grpc.MoveJobPOptionsOrBuilder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.WriteOptions.Builder
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
hasWriteType() - Method in class alluxio.grpc.WriteOptions
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
hasWriteType() - Method in interface alluxio.grpc.WriteOptionsOrBuilder
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
hasXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
hasXattrPropStrat() - Method in class alluxio.grpc.CreateDirectoryPOptions
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
hasXattrPropStrat() - Method in interface alluxio.grpc.CreateDirectoryPOptionsOrBuilder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
hasXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
hasXattrPropStrat() - Method in class alluxio.grpc.CreateFilePOptions
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
hasXattrPropStrat() - Method in interface alluxio.grpc.CreateFilePOptionsOrBuilder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
hasXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
hasXattrUpdateStrategy() - Method in class alluxio.grpc.SetAttributePOptions
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
hasXattrUpdateStrategy() - Method in interface alluxio.grpc.SetAttributePOptionsOrBuilder
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
hasXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
hasXAttrUpdateStrategy() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
hasXAttrUpdateStrategy() - Method in interface alluxio.proto.journal.File.UpdateInodeEntryOrBuilder
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
HDFS - Class in alluxio.examples
Example program to use HDFS API to read and write files.
HDFS() - Constructor for class alluxio.examples.HDFS
 
HDFS_ACL_PROVIDER_CLASS - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
Name of the class for the HDFS Acl provider.
HDFS_EC_CODEC_REGISTRY_CLASS - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
Name of the class for the HDFS EC Codec Registry.
HDFS_EC_MIN_VERSION - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
The minimum HDFS production version required for EC.
HDFS_TOOL_TYPE - Static variable in class alluxio.cli.ValidationConfig
 
HDFS_USER - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
HdfsAclProvider - Interface in alluxio.underfs.hdfs
Interface for providing HDFS ACLs.
HdfsConfParityValidationTask - Class in alluxio.cli.hdfs
Compares HDFS configuration in Alluxio and in HDFS environment variables.
HdfsConfParityValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsConfParityValidationTask
Constructor.
HdfsConfValidationTask - Class in alluxio.cli.hdfs
Class for validating HDFS-related configurations.
HdfsConfValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsConfValidationTask
Creates a new instance of HdfsConfValidationTask for validating HDFS configuration.
HdfsFileInputStream - Class in alluxio.hadoop
HdfsFileInputStream implement for hadoop 1 and hadoop 2.
HdfsFileInputStream(FileSystem, AlluxioURI, FileSystem.Statistics) - Constructor for class alluxio.hadoop.HdfsFileInputStream
Constructs a new stream for reading a file from HDFS.
HdfsFileInputStream(FileInStream, FileSystem.Statistics) - Constructor for class alluxio.hadoop.HdfsFileInputStream
Constructs a new stream for reading a file from HDFS.
HdfsPositionedUnderFileInputStream - Class in alluxio.underfs.hdfs
The input stream of HDFS as under filesystem.
HdfsProxyUserValidationTask - Class in alluxio.cli.hdfs
Validates the proxyuser configurations for alluxio in hdfs.
HdfsProxyUserValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsProxyUserValidationTask
Creates a new instance of HdfsProxyUserValidationTask for validating proxyuser configuration.
HdfsUnderFileInputStream - Class in alluxio.underfs.hdfs
The input stream of HDFS as under filesystem.
HdfsUnderFileOutputStream - Class in alluxio.underfs.hdfs
Output stream implementation for HdfsUnderFileSystem.
HdfsUnderFileOutputStream(FileSystem, String, FSDataOutputStream) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
Basic constructor.
HdfsUnderFileSystem - Class in alluxio.underfs.hdfs
HDFS UnderFileSystem implementation.
HdfsUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystem
Constructs a new HDFS UnderFileSystem.
HdfsUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration, boolean) - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
HdfsUnderFileSystemFactory - Class in alluxio.underfs.hdfs
Factory for creating HdfsUnderFileSystem.
HdfsUnderFileSystemFactory() - Constructor for class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
Constructs a new HdfsUnderFileSystemFactory.
HdfsValidationTool - Class in alluxio.cli
A tool to validate an HDFS mount, before the path is mounted to Alluxio.
HdfsValidationTool(String, UnderFileSystemConfiguration) - Constructor for class alluxio.cli.HdfsValidationTool
The constructor.
HdfsValidationToolFactory - Class in alluxio.cli
Factory to create an HDFS validation tool implementation.
HdfsValidationToolFactory() - Constructor for class alluxio.cli.HdfsValidationToolFactory
 
HdfsVersion - Enum in alluxio.underfs.hdfs
The set of supported Hdfs versions.
HdfsVersionValidationTask - Class in alluxio.cli.hdfs
Validates if the HDFS version works with the UFS version specified in alluxio configuration.
HdfsVersionValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.HdfsVersionValidationTask
Creates a new instance of HdfsVersionValidationTask for validating HDFS version.
HdfsWorker(int, int, int, ByteBuffer, boolean, String) - Constructor for class alluxio.examples.Performance.HdfsWorker
 
head(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the head method to send a url with arguments by http, this method can call RESTful Api.
headBucket(String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
HeadBucket - head a bucket to check for existence.
HeadCommand - Class in alluxio.cli.fs.command
Prints the file's first n bytes (by default, 1KB) to the console.
HeadCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.HeadCommand
 
HEADER - Static variable in class alluxio.Constants
 
HEADER_ABFS - Static variable in class alluxio.Constants
 
HEADER_ABFSS - Static variable in class alluxio.Constants
 
HEADER_ADL - Static variable in class alluxio.Constants
 
HEADER_ADLS - Static variable in class alluxio.Constants
 
HEADER_CEPHFS - Static variable in class alluxio.Constants
 
HEADER_CEPHFS_HADOOP - Static variable in class alluxio.Constants
 
HEADER_CHARSET - Static variable in class alluxio.s3.S3Constants
 
HEADER_COS - Static variable in class alluxio.Constants
 
HEADER_COSN - Static variable in class alluxio.Constants
 
HEADER_GCS - Static variable in class alluxio.Constants
 
HEADER_OBS - Static variable in class alluxio.Constants
 
HEADER_OSS - Static variable in class alluxio.Constants
 
HEADER_S3 - Static variable in class alluxio.Constants
 
HEADER_S3A - Static variable in class alluxio.Constants
 
HEADER_WASB - Static variable in class alluxio.Constants
 
HEADER_WASBS - Static variable in class alluxio.Constants
 
HealthCheckClient - Interface in alluxio
Client for checking service availability.
HeapBlockMetaStore - Class in alluxio.master.metastore.heap
This class requires external synchronization for operations on the same block id.
HeapBlockMetaStore() - Constructor for class alluxio.master.metastore.heap.HeapBlockMetaStore
constructor a HeapBlockStore.
HeapInodeStore - Class in alluxio.master.metastore.heap
FileStore implementation using on-heap data structures.
HeapInodeStore() - Constructor for class alluxio.master.metastore.heap.HeapInodeStore
Construct a heap inode store.
heartbeat(long) - Method in class alluxio.client.file.ConfigHashSync
 
heartbeat() - Method in class alluxio.client.metrics.ClientMasterSync
Sends metrics to the master keyed with appId and client hostname.
heartbeat(List<ClientMetrics>) - Method in interface alluxio.client.metrics.MetricsMasterClient
The method the worker should periodically execute to heartbeat back to the master.
heartbeat(List<ClientMetrics>) - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
 
heartbeat(long) - Method in class alluxio.fuse.meta.UpdateChecker
Heartbeat for the periodic update check.
heartbeat(JobHeartbeatPRequest, StreamObserver<JobHeartbeatPResponse>) - Method in interface alluxio.grpc.JobMasterWorkerServiceGrpc.AsyncService
Periodic worker heartbeat returns a list of commands for the worker to execute.
heartbeat(JobHeartbeatPRequest) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceBlockingStub
Periodic worker heartbeat returns a list of commands for the worker to execute.
heartbeat(JobHeartbeatPRequest) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceFutureStub
Periodic worker heartbeat returns a list of commands for the worker to execute.
heartbeat(JobHeartbeatPRequest, StreamObserver<JobHeartbeatPResponse>) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceStub
Periodic worker heartbeat returns a list of commands for the worker to execute.
heartbeat(long) - Method in interface alluxio.heartbeat.HeartbeatExecutor
Implements the heartbeat logic.
heartbeat(long) - Method in class alluxio.master.block.DefaultBlockMaster.LostWorkerDetectionHeartbeatExecutor
 
heartbeat(long) - Method in class alluxio.master.block.DefaultBlockMaster.WorkerRegisterStreamGCExecutor
 
heartbeat(JobHeartbeatPRequest, StreamObserver<JobHeartbeatPResponse>) - Method in class alluxio.master.job.JobMasterWorkerServiceHandler
 
heartbeat(long) - Method in class alluxio.master.meta.JobMasterSync
Heartbeats to the leader master node.
heartbeat(long) - Method in class alluxio.master.meta.JournalSpaceMonitor
 
heartbeat(long) - Method in class alluxio.master.meta.MetaMasterSync
Heartbeats to the leader master node.
heartbeat(long) - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
Sends a heartbeat to the leader master.
heartbeat(long) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Sends a heartbeat to the leader master.
heartbeat(long) - Method in class alluxio.master.meta.UpdateChecker
Heartbeat for the periodic update check.
heartbeat(long) - Method in class alluxio.proxy.ProxyMasterSync
Heartbeats to the primary master node.
heartbeat() - Method in class alluxio.SessionInfo
Performs a session heartbeat.
heartbeat(long, Map<String, Long>, Map<String, Long>, List<Long>, Map<BlockStoreLocation, List<Long>>, Map<String, List<String>>, List<Metric>) - Method in class alluxio.worker.block.BlockMasterClient
The method the worker should periodically execute to heartbeat back to the master.
heartbeat(long) - Method in class alluxio.worker.job.command.CommandHandlingExecutor
 
heartbeat(JobWorkerHealth, List<JobInfo>) - Method in interface alluxio.worker.job.JobMasterClient
Periodic heartbeats to update the tasks' status from a worker, and returns the commands.
heartbeat(JobWorkerHealth, List<JobInfo>) - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
 
HeartbeatContext - Class in alluxio.heartbeat
This is a static class for storing and retrieving heartbeat related information.
HeartbeatContext.HeartbeatType - Enum in alluxio.heartbeat
HeartBeat Enum Type.
HeartbeatExecutor - Interface in alluxio.heartbeat
An interface for a heartbeat execution.
HeartbeatHandler - Class in alluxio.worker.netty
A handler for heartbeat events.
HeartbeatHandler() - Constructor for class alluxio.worker.netty.HeartbeatHandler
Constructs a new heartbeat handler.
HeartbeatScheduler - Class in alluxio.heartbeat
This class can be used for controlling heartbeat execution of a thread.
HeartbeatThread - Class in alluxio.heartbeat
Thread class to execute a heartbeat periodically.
HeartbeatThread(String, String, HeartbeatExecutor, Supplier<SleepIntervalSupplier>, AlluxioConfiguration, UserState, Clock) - Constructor for class alluxio.heartbeat.HeartbeatThread
Creates a Runnable to execute heartbeats for the given HeartbeatExecutor.
HeartbeatThread(String, HeartbeatExecutor, Supplier<SleepIntervalSupplier>, AlluxioConfiguration, UserState) - Constructor for class alluxio.heartbeat.HeartbeatThread
HeartbeatThread(String, HeartbeatExecutor, Supplier<SleepIntervalSupplier>, AlluxioConfiguration, UserState, Clock) - Constructor for class alluxio.heartbeat.HeartbeatThread
HeartbeatThread.Status - Enum in alluxio.heartbeat
Enum representing the status of HeartbeatThread.
HeartbeatTimer - Interface in alluxio.heartbeat
An interface for heartbeat timers.
HELP_FLAG - Static variable in class alluxio.stress.BaseParameters
 
HELP_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.DoctorCommand
 
HELP_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
HelpCommand - Class in alluxio.cli.fs.command
Command for print help message for the given command.
HelpCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.HelpCommand
 
helpComplete(int) - Method in class alluxio.concurrent.jsr.CountedCompleter
If this task has not completed, attempts to process at most the given number of other unprocessed tasks for which this task is on the completion path, if any are known to exist.
helpQuiesce() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Possibly executes tasks until the pool hosting the current task is quiescent.
HFSUtils - Class in alluxio.util
Utility method called in alluxio-mount.sh to calculate space for Mac OS X HFS+.
HIGH_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Range
 
HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DateColumnStatsData
 
HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DecimalColumnStatsData
 
HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DoubleColumnStatsData
 
HIGH_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LongColumnStatsData
 
histogram(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add a histogram with the given name.
HISTOGRAM_VALUE - Static variable in enum alluxio.grpc.MetricType
HISTOGRAM gives statistics about the value of past occurrences of an event.
HiveBucketProperty - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.HiveBucketProperty
HiveBucketProperty.Builder - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.HiveBucketProperty
HiveBucketPropertyOrBuilder - Interface in alluxio.grpc.table.layout.hive
 
HiveCacheContext - Class in alluxio.client.hive
Data structure that stores and returns Hive related Cache Scope.
HiveCacheContext(String, String, String) - Constructor for class alluxio.client.hive.HiveCacheContext
Constructor.
HiveLayoutProto - Class in alluxio.grpc.table.layout.hive
 
HMS_TOOL_TYPE - Static variable in class alluxio.cli.ValidationConfig
 
HmsValidationTool - Class in alluxio.cli
Run tests against an existing hive metastore.
HmsValidationToolFactory - Class in alluxio.cli
Factory to create hive metastore validation tool implementation.
HmsValidationToolFactory() - Constructor for class alluxio.cli.HmsValidationToolFactory
 
HOME - Static variable in class alluxio.conf.PropertyKey
 
HOME - Static variable in class alluxio.conf.PropertyKey.Name
 
HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.NetAddress
 
HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
 
HOSTNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
HOUR - Static variable in class alluxio.Constants
 
HOUR_MS - Static variable in class alluxio.Constants
 
HTTP_VERSION - Static variable in class alluxio.s3.NettyRestUtils
 
HttpFilter - Class in alluxio.web
Provides an abstract class to be subclassed to create an HTTP filter.
HttpFilter() - Constructor for class alluxio.web.HttpFilter
 
HttpRequestUri - Class in alluxio.worker.http
A wrapped DO of the HTTP request URI.
HttpRequestUtil - Class in alluxio.worker.http
Util class for handling HTTP request.
HttpRequestUtil() - Constructor for class alluxio.worker.http.HttpRequestUtil
 
HttpResponseContext - Class in alluxio.worker.http
Http response context for wrapping useful information.
HttpResponseContext(HttpResponse, FileRegion) - Constructor for class alluxio.worker.http.HttpResponseContext
Http response context for wrapping useful information.
HttpServer - Class in alluxio.worker.http
HttpServer provides Alluxio RESTful API.
HttpServer(HttpServerInitializer) - Constructor for class alluxio.worker.http.HttpServer
HttpServer provides Alluxio RESTful API.
HttpServerHandler - Class in alluxio.worker.http
HttpServerHandler deals with HTTP requests received from Netty Channel.
HttpServerHandler(PagedService) - Constructor for class alluxio.worker.http.HttpServerHandler
HttpServerHandler deals with HTTP requests received from Netty Channel.
HttpServerInitializer - Class in alluxio.worker.http
HttpServerInitializer is used for initializing the Netty pipeline of HTTP Server.
HttpServerInitializer(PagedService) - Constructor for class alluxio.worker.http.HttpServerInitializer
HttpServerInitializer is used for initializing the Netty pipeline of HTTP Server.
HttpUtils - Class in alluxio.util.network
Utility methods for working with http.
HttpUtils.IProcessInputStream - Interface in alluxio.util.network
This interface should be implemented by the http response body stream processor.

I

IBM_JAVA - Static variable in class alluxio.util.OSUtils
Indicates the current java vendor is IBM java or not.
ID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
ID_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
ID_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyInfo
 
ID_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobWorkerPResponse
 
ID_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FieldSchema
 
ID_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
ID_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.NewBlockEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistDirectoryEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAclEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
ID_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
ID_FLAG - Static variable in class alluxio.stress.BaseParameters
 
ID_INDEX - Static variable in class alluxio.fuse.AlluxioJniFuseFileSystem
 
ID_NOT_SET_VALUE - Static variable in class alluxio.fuse.AlluxioFuseUtils
 
ID_NOT_SET_VALUE_UNSIGNED - Static variable in class alluxio.fuse.AlluxioFuseUtils
 
ID_PARAM - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
ID_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
ID = 4;
IDENTIFIER_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerIdentity
 
IdentityUserGroupsMapping - Class in alluxio.security.group.provider
A simple implementation of GroupMappingService that returns a group which is same name with the given user name.
IdentityUserGroupsMapping() - Constructor for class alluxio.security.group.provider.IdentityUserGroupsMapping
Constructs a new IdentityUserGroupsMapping.
IdleReadHandler - Class in alluxio.worker.netty
Closes the channel if it has been idle for too long.
IdleReadHandler() - Constructor for class alluxio.worker.netty.IdleReadHandler
Creates a new idle read handler.
IdleWriteHandler - Class in alluxio.network.netty
Sends a keep-alive to the server whenever the channel has been idle for a period of time.
IdleWriteHandler() - Constructor for class alluxio.network.netty.IdleWriteHandler
Creates a new idle write handler.
IdUtils - Class in alluxio.util
Utility methods for working with an id in Alluxio.
IGNORE_SYNC_ERRORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
IGNORECLUSTERCONF_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPOptions
 
IGNOREPATHCONF_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPOptions
 
ImmutableCacheUsageView(long, long, long) - Constructor for class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
Constructor.
IMPERSONATION_HDFS_USER - Static variable in class alluxio.Constants
 
IMPERSONATION_NONE - Static variable in class alluxio.Constants
 
ImpersonationAuthenticator - Class in alluxio.security.authentication
An authenticator for impersonation users.
ImpersonationAuthenticator(AlluxioConfiguration) - Constructor for class alluxio.security.authentication.ImpersonationAuthenticator
Constructs a new ImpersonationAuthenticator.
imply(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
Checks whether these bits imply the given bits.
IMPORTED_VALUE - Static variable in enum alluxio.grpc.table.TableInfo.TableType
IMPORTED = 1;
IN_ALLUXIO_STATE_DIR - Static variable in class alluxio.cli.fs.command.LsCommand
 
IN_ALLUXIO_STATE_FILE - Static variable in class alluxio.cli.fs.command.LsCommand
 
IN_PROCESS_FLAG - Static variable in class alluxio.stress.BaseParameters
 
INALLUXIOPERCENTAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
inc() - Method in class alluxio.concurrent.CountingLatch
Increases the counter.
INCLUDE_OPTION_NAME - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
 
INCLUDEREALCONTENTHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPOptions
 
INCONSISTENTPATHS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckConsistencyPResponse
 
InconsistentProperties - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.InconsistentProperties
InconsistentProperties.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.InconsistentProperties
InconsistentPropertiesOrBuilder - Interface in alluxio.grpc
 
InconsistentProperty - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.InconsistentProperty
InconsistentProperty - Class in alluxio.wire
Records a property that is required or recommended to be consistent but is not within its scope.
InconsistentProperty() - Constructor for class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty.
InconsistentProperty(InconsistentProperty) - Constructor for class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty from proto representation.
InconsistentProperty.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.InconsistentProperty
InconsistentPropertyOrBuilder - Interface in alluxio.grpc
 
InconsistentPropertyValues - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.InconsistentPropertyValues
InconsistentPropertyValues.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.InconsistentPropertyValues
InconsistentPropertyValuesOrBuilder - Interface in alluxio.grpc
 
increaseOperationCount(int) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
By calling this method, cuckoo filter is informed of the number of entries have passed.
incrementCounter(String, long) - Method in class alluxio.client.file.CacheContext
Increments the counter name by value.
incrementCounter(String, CacheContext.StatsUnit, long) - Method in class alluxio.client.file.CacheContext
Increments the counter name by value.
incrementForAllConfigsCancelStatus(JobConfig) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment for both batch and non-batch configs for Cancel status.
incrementForAllConfigsCompleteStatus(JobConfig, FileSystem, RetryPolicy) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment for both batch and non-batch configs for COMPLETE status.
incrementForAllConfigsFailStatus(JobConfig) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment for both batch and non-batch configs for Fail status.
incrementForCancelStatus(String, long) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment cancelled job count.
incrementForCompleteStatusWithRetry(JobConfig, FileSystem, RetryPolicy) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment for non-batch config for complete status.
incrementForFailStatus(String, long) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment failed job count.
incrementIOBytes(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
Increments the bytes of IO an amount.
incrementIOBytes(long) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
Increments the bytes of IO an amount.
INDEX_FLAG - Static variable in class alluxio.stress.BaseParameters
 
IndexDefinition<T,V> - Class in alluxio.collections
A class representing an index for an IndexedSet.
IndexDefinition(boolean) - Constructor for class alluxio.collections.IndexDefinition
Constructs a new IndexDefinition instance.
IndexedSet<T> - Class in alluxio.collections
A set of objects that are indexed and thus can be queried by specific fields of the object.
IndexedSet(IndexDefinition<T, ?>, IndexDefinition<T, ?>...) - Constructor for class alluxio.collections.IndexedSet
Constructs a new IndexedSet instance with at least one field as the index.
indexHash(int, int) - Static method in class alluxio.client.file.cache.cuckoofilter.CuckooUtils
Computes the bucket index on given hash value.
indexOf(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
IndexType - Enum in alluxio.master.metastore.rocks
IndexType used in conjunction with BlockBasedTable.
inferFileStartTime(File) - Static method in class alluxio.cli.bundler.command.CollectLogCommand
Infer the starting time of a log file by parsing the log entries from the beginning.
info(String) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
INFO_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
INFO_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey
 
INFO_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey.Name
 
inForkJoinPool() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.
INFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetActionInfoResponse
 
init(int, int, int, BaseFileStructure.Distribution) - Method in class alluxio.BaseFileStructure
 
init(ThreadParams) - Method in class alluxio.BaseThreadState
 
init(ClientContext, MasterInquireClient) - Method in class alluxio.client.file.FileSystemContext
Initializes the context.
init(FileSystemBase.ServerType, int, String, int) - Method in class alluxio.fsmaster.FileSystemBase
 
init() - Method in interface alluxio.fuse.auth.AuthPolicy
Initialize the authentication policy.
init() - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
init(RaftStorage) - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
init() - Method in class alluxio.master.journal.ufs.UfsJournal
 
init() - Method in class alluxio.proxy.s3.S3Handler
Initialize the S3Handler object in preparation for handling the request.
init() - Method in class alluxio.underfs.oss.StsOssClientProvider
init(AlluxioConfiguration) - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
init(AlluxioConfiguration) - Method in interface alluxio.util.network.tls.SslContextProvider
Initializes provider.
init(FilterConfig) - Method in class alluxio.web.HttpFilter
 
init() - Method in class alluxio.web.JmxServlet
Initialize this servlet.
init() - Method in class alluxio.worker.s3.S3NettyHandler
Initialize the S3Handler object in preparation for handling the request.
initChannel(SocketChannel) - Method in class alluxio.worker.http.HttpServerInitializer
 
initChannel(SocketChannel) - Method in class alluxio.worker.s3.S3HttpPipelineHandler
 
initConfiguration(String) - Method in class alluxio.master.AbstractLocalAlluxioCluster
Creates a default Configuration for testing.
initConfiguration(String) - Method in class alluxio.master.LocalAlluxioCluster
 
initConfiguration(String) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
initConfiguration(String) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
initContext(ClientContext, MasterInquireClient) - Method in class alluxio.client.file.FileSystemContext
 
initFromBackup(InputStream) - Method in class alluxio.master.BackupManager
Restores master state from the specified backup.
initialize(URI, Configuration) - Method in class alluxio.hadoop.AbstractFileSystem
Sets up a lazy connection to Alluxio through mFileSystem.
initialize(URI, Configuration, AlluxioConfiguration) - Method in class alluxio.hadoop.AbstractFileSystem
Initialize the FileSystem.
initialize(URI, Configuration) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
initialize(RaftServer, RaftGroupId, RaftStorage) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class alluxio.security.login.AlluxioLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class alluxio.security.login.AppLoginModule
 
initialize() - Method in interface alluxio.worker.block.BlockStore
Initialize the block store.
initializeJob() - Method in class alluxio.master.job.AbstractJob
 
initializeJob() - Method in interface alluxio.scheduler.job.Job
Initialize the job before kick it running.
initializeOSSClientConfig(AlluxioConfiguration) - Static method in class alluxio.underfs.oss.OSSUnderFileSystem
Creates an OSS ClientConfiguration using an Alluxio Configuration.
initializeRoot(String, String, Mode, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Initializes the root of the inode tree.
Initially_Synced_VALUE - Static variable in enum alluxio.grpc.SyncPointStatus
Initially_Synced = 2;
initiateMultipartUpload(String, String, String, String, String) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Initiates or completes a multipart upload based on query parameters.
InitiateMultipartUploadResult - Class in alluxio.proxy.s3
Result returned after requests for initiating a multipart upload.
InitiateMultipartUploadResult() - Constructor for class alluxio.proxy.s3.InitiateMultipartUploadResult
Constructs an InitiateMultipartUploadResult with fields initialized to empty strings.
InitiateMultipartUploadResult(String, String, String) - Constructor for class alluxio.proxy.s3.InitiateMultipartUploadResult
Constructs an InitiateMultipartUploadResult with the specified values.
initiateVerification() - Method in class alluxio.master.job.CopyJob
 
initiateVerification() - Method in class alluxio.master.job.DoraLoadJob
 
initiateVerification() - Method in class alluxio.master.job.LoadJob
 
initiateVerification() - Method in class alluxio.master.job.MoveJob
 
initiateVerification() - Method in interface alluxio.scheduler.job.Job
Initiate a verification pass.
Initiating_VALUE - Static variable in enum alluxio.grpc.BackupState
Initiating = 2;
initMetricKeys() - Method in class alluxio.master.metrics.MetricsStore
Inits the metrics store.
initMultipartUploadInternal() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
initMultiPartUploadInternal() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
initMultipartUploadInternal() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
initMultiPartUploadInternal() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
initMultipartUploadInternal() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
initMultiPartUploadInternal() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
initMultipartUploadInternal() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
initMultiPartUploadInternal() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
initMultipartUploadInternal() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
initRequestContext(BlockWriteRequestContext) - Method in class alluxio.worker.netty.FileWriteHandler
 
initRequestContext(UfsFileWriteRequestContext) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
initShouldReportMetrics(MetricsSystem.InstanceType) - Static method in class alluxio.metrics.MetricsSystem
inList(String) - Method in class alluxio.collections.PrefixList
Checks whether a prefix of path is in the prefix list.
INMEMORYPERCENTAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
Inode - Class in alluxio.master.file.meta
Base class for read only inodes.
Inode(InodeView) - Constructor for class alluxio.master.file.meta.Inode
 
INODE_DIRECTORY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
INODE_DIRECTORY_ID_GENERATOR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
INODE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
INODE_LAST_MODIFICATION_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
INODE_SYNC_STREAM_ACTIVE_PATHS_TOTAL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_COUNT - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_FAIL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_NO_CHANGE - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_PENDING_PATHS_TOTAL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_SKIPPED - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_SUCCESS - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_SYNC_PATHS_CANCEL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_SYNC_PATHS_FAIL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_SYNC_PATHS_SUCCESS - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
INODE_SYNC_STREAM_TIME_MS - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
InodeBenchRead - Class in alluxio.inode
This benchmark measures the time it takes to read inodes from a tree like structure, this includes locking and traversing the read path.
InodeBenchRead() - Constructor for class alluxio.inode.InodeBenchRead
 
InodeBenchRead.Db - Class in alluxio.inode
 
InodeBenchRead.ThreadState - Class in alluxio.inode
 
InodeBenchWrite - Class in alluxio.inode
This benchmark measures the time it takes to write inodes to a tree like structure, this includes locking and traversing the path.
InodeBenchWrite() - Constructor for class alluxio.inode.InodeBenchWrite
 
InodeBenchWrite.Db - Class in alluxio.inode
 
InodeBenchWrite.ThreadState - Class in alluxio.inode
 
InodeCounter - Class in alluxio.master.file.meta
A checkpointed long adder.
InodeCounter() - Constructor for class alluxio.master.file.meta.InodeCounter
 
InodeDirectory - Class in alluxio.master.file.meta
Forwarding wrapper around an inode directory view.
InodeDirectory(InodeDirectoryView) - Constructor for class alluxio.master.file.meta.InodeDirectory
 
InodeDirectoryIdGenerator - Class in alluxio.master.file.meta
Inode id management for directory inodes.
InodeDirectoryIdGenerator(ContainerIdGenerable) - Constructor for class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
InodeDirectoryView - Interface in alluxio.master.file.meta
Read-only interface for an inode directory.
InodeFile - Class in alluxio.master.file.meta
Forwarding wrapper around an inode file view.
InodeFile(InodeFileView) - Constructor for class alluxio.master.file.meta.InodeFile
 
InodeFileView - Interface in alluxio.master.file.meta
Read-only interface for an inode file.
inodeIdExists(long) - Method in class alluxio.master.file.meta.InodeTree
 
InodeLockList - Interface in alluxio.master.file.meta
Represents a locked path within the inode tree.
InodeLockManager - Class in alluxio.master.file.meta
Class for managing inode locking.
InodeLockManager() - Constructor for class alluxio.master.file.meta.InodeLockManager
Creates a new instance of InodeLockManager.
InodeMeta - Class in alluxio.proto.meta
 
InodeMeta.Inode - Class in alluxio.proto.meta
General inode metadata.
InodeMeta.Inode.Builder - Class in alluxio.proto.meta
General inode metadata.
InodeMeta.InodeOrBuilder - Interface in alluxio.proto.meta
 
inodePathExists(AlluxioURI) - Method in class alluxio.master.file.meta.InodeTree
 
InodePathPair - Class in alluxio.master.file.meta
This class represents a pair of LockedInodePaths.
InodeProtosCheckpointFormat - Class in alluxio.master.journal.checkpoint
Reads inode proto checkpoints.
InodeProtosCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.InodeProtosCheckpointFormat
 
InodeStore - Interface in alluxio.master.metastore
Inode metadata storage.
InodeStore.Factory - Interface in alluxio.master.metastore
Factory for creating inode stores.
InodeStore.WriteBatch - Interface in alluxio.master.metastore
Used to perform batched writes.
InodeSyncStream - Class in alluxio.master.file
This class is responsible for maintaining the logic which surrounds syncing metadata between Alluxio and its UFSes.
InodeSyncStream(LockingScheme, DefaultFileSystemMaster, UfsSyncPathCache, RpcContext, DescendantType, FileSystemMasterCommonPOptions, FileSystemMasterAuditContext, Function<LockedInodePath, Inode>, boolean, boolean, boolean) - Constructor for class alluxio.master.file.InodeSyncStream
Create a new instance of InodeSyncStream.
InodeSyncStream(LockingScheme, DefaultFileSystemMaster, UfsSyncPathCache, RpcContext, DescendantType, FileSystemMasterCommonPOptions, boolean, boolean, boolean) - Constructor for class alluxio.master.file.InodeSyncStream
Create a new instance of InodeSyncStream without any audit or permission checks.
InodeSyncStream.SyncStatus - Enum in alluxio.master.file
Return status of a sync result.
InodeTree - Class in alluxio.master.file.meta
Represents the tree of Inodes.
InodeTree(InodeStore, ContainerIdGenerable, InodeDirectoryIdGenerator, MountTable, InodeLockManager) - Constructor for class alluxio.master.file.meta.InodeTree
 
InodeTree.LockPattern - Enum in alluxio.master.file.meta
Patterns of inode path locking.
InodeTreeBufferedIterator - Class in alluxio.master.file.meta
Used to iterate this InodeTree's state, while doing a read-ahead buffering.
InodeTreePersistentState - Class in alluxio.master.file.meta
Class for managing persistent inode tree state.
InodeTreePersistentState(InodeStore, InodeLockManager, TtlBucketList) - Constructor for class alluxio.master.file.meta.InodeTreePersistentState
 
inodeUfsIsContentSynced(Inode, Fingerprint, Fingerprint) - Static method in class alluxio.master.file.meta.UfsSyncUtils
Returns true if the given inode's content is synced with the ufs status.
inodeUfsIsMetadataSynced(Inode, Fingerprint, Fingerprint) - Static method in class alluxio.master.file.meta.UfsSyncUtils
Returns true if the given inode's metadata matches the ufs fingerprint.
InodeView - Interface in alluxio.master.file.meta
Read-only view of an inode.
inProgress() - Method in class alluxio.master.backup.BackupTracker
 
INPUT_FORMAT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.StorageFormat
 
insert(Inode) - Method in class alluxio.master.file.meta.TtlBucketList
Insert inode to the ttlbucket with default number of retry attempts.
insert(Inode, int) - Method in class alluxio.master.file.meta.TtlBucketList
Inserts an inode to the appropriate bucket where its ttl end time lies in the bucket's interval, if no appropriate bucket exists, a new bucket will be created to contain this inode, if ttl value is Constants.NO_TTL, the inode won't be inserted to any buckets and nothing will happen.
insert(Long) - Method in class alluxio.util.BucketCounter
insert a number to be counted.
insertOrKickTag(int, int) - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
Insert a tag into specified bucket.
insertOrKickTag(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
InstallCommand - Class in alluxio.cli.extensions.command
Install a new extension.
InstallCommand() - Constructor for class alluxio.cli.extensions.command.InstallCommand
Constructs a new instance of InstallCommand.
INSTANCE - Static variable in class alluxio.grpc.GrpcChannelPool
 
INSTANCE - Static variable in class alluxio.master.file.NoopBlockDeletionContext
 
INSTANCE - Static variable in class alluxio.master.file.NoopUfsDeleter
 
INSTANCE - Static variable in class alluxio.master.journal.NoopJournalContext
 
instance() - Static method in class alluxio.resource.AlluxioResourceLeakDetectorFactory
 
INSTANCE - Static variable in class alluxio.resource.NoopCloseable
 
INSTANCE - Static variable in class alluxio.time.SteppingThreadSleeper
 
INSTANCE - Static variable in class alluxio.time.ThreadSleeper
 
INSTANCE - Static variable in class alluxio.uri.NoAuthority
 
INSTANCE - Static variable in class alluxio.wire.WorkerIdentity.ParserV0
 
INSTANCE - Static variable in class alluxio.wire.WorkerIdentity.ParserV1
 
INSTANCE_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
 
InstancedConfiguration - Class in alluxio.conf
Alluxio configuration.
InstancedConfiguration(AlluxioProperties) - Constructor for class alluxio.conf.InstancedConfiguration
Creates a new instance of InstancedConfiguration.
InstancedConfiguration(AlluxioProperties, boolean) - Constructor for class alluxio.conf.InstancedConfiguration
Creates a new instance of InstancedConfiguration.
InstancedConfiguration.UnresolvablePropertyException - Exception in alluxio.conf
 
instant() - Method in class alluxio.clock.ElapsedTimeClock
 
instant() - Method in class alluxio.clock.SystemClock
 
InStreamOptions - Class in alluxio.client.file.options
Information for reading a file.
InStreamOptions(URIStatus, AlluxioConfiguration) - Constructor for class alluxio.client.file.options.InStreamOptions
Creates with the default OpenFilePOptions.
InStreamOptions(URIStatus, AlluxioConfiguration, FileSystemContext) - Constructor for class alluxio.client.file.options.InStreamOptions
Creates with the default OpenFilePOptions.
InStreamOptions(URIStatus, OpenFilePOptions, AlluxioConfiguration, FileSystemContext) - Constructor for class alluxio.client.file.options.InStreamOptions
Creates with given OpenFilePOptions instance.
InstrumentedExecutorService - Class in alluxio.metrics
A wrapper around InstrumentedExecutorService that allows the metrics to be reset by MetricsSystem.resetAllMetrics().
InstrumentedExecutorService(ExecutorService, MetricRegistry, String) - Constructor for class alluxio.metrics.InstrumentedExecutorService
 
intAsUnsignedByteValue(int) - Static method in class alluxio.util.io.BufferUtils
Gets the unsigned byte value of an integer.
intBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
intercept(ClientInterceptor) - Method in class alluxio.grpc.GrpcChannel
Registers interceptor to the channel.
intercept(ServerInterceptor) - Method in class alluxio.grpc.GrpcServerBuilder
Adds an interceptor for this server.
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class alluxio.client.block.stream.StreamSerializationClientInterceptor
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class alluxio.grpc.ClientVersionClientInjector
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class alluxio.security.authentication.AuthenticatedUserInjector
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class alluxio.security.authentication.ChannelIdInjector
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class alluxio.security.authentication.ClientContextServerInjector
 
INTERNAL_ERROR - Static variable in class alluxio.s3.S3ErrorCode
 
INTERNAL_ERROR - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INTERNAL_SESSION_ID_BASE - Static variable in class alluxio.Sessions
 
Internal_VALUE - Static variable in enum alluxio.grpc.ErrorType
Internal = 1;
INTERNAL_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
Internal errors.
InternalException - Exception in alluxio.exception.status
Exception representing an internal error.
InternalException(String) - Constructor for exception alluxio.exception.status.InternalException
 
InternalException(Throwable) - Constructor for exception alluxio.exception.status.InternalException
 
InternalException(String, Throwable) - Constructor for exception alluxio.exception.status.InternalException
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ActionInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ActionInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddPolicyPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddPolicyPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddPolicyPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AddQuorumServerRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AsyncCacheRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.AsyncCacheResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupPStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupPStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BackupStatusPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Block.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Block
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockIdList.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockIdList
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockLocation.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockLocation
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockMasterInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BlockStoreLocationProto
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BuildVersion.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.BuildVersion
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CacheRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CacheRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CacheResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CacheResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CancelTaskCommand
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckAccessPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckAccessPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckAccessPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckpointPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckpointPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CheckResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Chunk.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Chunk
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClearMetricsResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClientMetrics.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ClientMetrics
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CmdProgress.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CmdProgress
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CmdStatusBlock
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CmdSummary.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CmdSummary
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Command.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Command
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CommitBlockPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CompleteFilePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CompleteFilePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CompleteFilePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ConfigCheckReport
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ConfigProperties.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ConfigProperties
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ConfigProperty.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ConfigProperty
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CopyJobPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CopyRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CopyRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CopyResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CopyResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateFilePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateFilePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.CreateFilePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DeletePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DeletePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DeletePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DeletePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DeletePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DeletePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ErrorInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ErrorInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ExistsPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ExistsPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ExistsPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.File.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.File
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileBlockInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileFailure.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileFailure
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemCommand
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemCommandOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreeWorkerRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FreeWorkerResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FsOpPId.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.FsOpPId
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetActionInfoOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetActionInfoRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetActionInfoResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetCmdStatusResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigHashPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigHashPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigReportPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigReportPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigurationPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetConfigurationPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFileInfoPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFileInfoPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFileInfoPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFilePathPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetFilePathPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobProgressPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobProgressPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetJobStatusPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterIdPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterIdPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterIdPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMetricsPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMetricsPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountIdPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountIdPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountTablePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetMountTablePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNodeStatePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetNodeStatePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStatusPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStatusPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetStatusPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.InconsistentProperties
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.InconsistentProperty
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.InconsistentPropertyValues
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobCommand.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobCommand
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobDescription.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobDescription
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobMasterStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobProgress.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobProgress
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobProgressPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobServiceSummary
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobStatusBlock
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobUnused.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobUnused
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JobWorkerHealth
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JournalQueryRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListAllPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListAllPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListAllPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListPolicyPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListPolicyPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListPolicyPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ListStatusPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadFileFailure
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadFileRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadFileResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadJobPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadMetadataPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LoadResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterVersion.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MasterVersion
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MessagingRequestHeader
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MessagingResponseHeader
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Metric.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Metric
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricValue.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MetricValue
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPointInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPointInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MountPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveBlockRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveBlockResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveJobPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.MoveResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NeedsSyncRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NeedsSyncResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NetAddress.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NetAddress
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.OpenFilePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PAcl.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PAcl
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PAclEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PAclEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PersistCommandOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PersistFile.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PersistFile
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PMode.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PMode
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PolicyInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PolicyInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PolicyStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.PolicyStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ProxyStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.QuorumServerInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReadRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReadRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReadResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReadResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterCommand.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterCommand
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterMasterPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterMasterPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterMasterPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveBlockRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveBlockResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePolicyPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePolicyPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemovePolicyPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RenamePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RenamePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RenamePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RenamePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RenamePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RenamePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RetryInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RetryInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReverseResolvePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ReverseResolvePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Route.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.Route
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RouteFailure.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RouteFailure
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.RunTaskCommand
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.S3SyntaxOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SaslMessage.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SaslMessage
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAclPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAclPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAclPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAttributePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAttributePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetAttributePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SnapshotData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SnapshotData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SnapshotMetadata
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StatusSummary.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StatusSummary
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopJobPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StopJobPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StorageList.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.StorageList
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitJobPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitJobPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.SubmitResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.AllOrNoneSet
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Constraint.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Constraint
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Database.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Database
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Date.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Date
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DateColumnStatsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Decimal.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Decimal
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Domain.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Domain
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.EquatableValueSet
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.FieldSchema
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.FileStatistics
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTablePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTablePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Layout.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.Storage
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Layout
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.LayoutSpec
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.LongColumnStatsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Partition.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Partition
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.PartitionSpec
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Range.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Range
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.RangeSet.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.RangeSet
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ReadTablePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.ReadTablePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Schema.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Schema
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.StringColumnStatsData
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.SyncStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TableInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TableInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Transformation.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Transformation
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TransformJobInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TransformTablePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.TransformTablePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Value.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.table.Value
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TierList.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TierList
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeaderMessage
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransportMessage.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TransportMessage
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TriggerPolicyRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.TriggerPolicyResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsFileStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsReadOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UfsStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UnmountPOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UnmountPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UnmountPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateMountPRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateMountPResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerIdentity
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WorkerNetAddress
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteRequestCommand
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.grpc.WriteResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.Response
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.RenameEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.SetAclEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.StringPairEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.FileFilter
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.Block.BlockLocation
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.Block.BlockMeta
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.AclActions
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.AclEntry
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
internalGetFieldAccessorTable() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
internalGetMapField(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
internalGetMapField(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
internalGetMapField(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.BlockMasterInfo
 
internalGetMapField(int) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.ConfigCheckReport
 
internalGetMapField(int) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.CreateDirectoryPOptions
 
internalGetMapField(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.CreateFilePOptions
 
internalGetMapField(int) - Method in class alluxio.grpc.FileInfo.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.FileInfo
 
internalGetMapField(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.GetConfigurationPResponse
 
internalGetMapField(int) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.GetMetricsPResponse
 
internalGetMapField(int) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.GetMountTablePResponse
 
internalGetMapField(int) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.InconsistentProperty
 
internalGetMapField(int) - Method in class alluxio.grpc.Metric.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.Metric
 
internalGetMapField(int) - Method in class alluxio.grpc.MountPointInfo.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.MountPointInfo
 
internalGetMapField(int) - Method in class alluxio.grpc.MountPOptions.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.MountPOptions
 
internalGetMapField(int) - Method in class alluxio.grpc.PolicyStatus.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.PolicyStatus
 
internalGetMapField(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.RegisterWorkerPRequest
 
internalGetMapField(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.SetAttributePOptions
 
internalGetMapField(int) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
internalGetMapField(int) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
internalGetMapField(int) - Method in class alluxio.grpc.table.Constraint.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.Constraint
 
internalGetMapField(int) - Method in class alluxio.grpc.table.Database.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.Database
 
internalGetMapField(int) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.FileStatistics
 
internalGetMapField(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
internalGetMapField(int) - Method in class alluxio.grpc.table.Layout.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
internalGetMapField(int) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.layout.hive.Storage
 
internalGetMapField(int) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
internalGetMapField(int) - Method in class alluxio.grpc.table.Layout
 
internalGetMapField(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.SyncStatus
 
internalGetMapField(int) - Method in class alluxio.grpc.table.TableInfo.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.table.TableInfo
 
internalGetMapField(int) - Method in class alluxio.grpc.UfsStatus.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.UfsStatus
 
internalGetMapField(int) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
internalGetMapField(int) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
internalGetMapField(int) - Method in class alluxio.grpc.WorkerInfo.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.WorkerInfo
 
internalGetMapField(int) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
internalGetMapField(int) - Method in class alluxio.grpc.WorkerLostStorageInfo
 
internalGetMapField(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
internalGetMapField(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.File.InodeFileEntry
 
internalGetMapField(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
internalGetMapField(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
internalGetMapField(int) - Method in class alluxio.proto.meta.InodeMeta.Inode
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.FileInfo.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.Metric.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.MountPointInfo.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.MountPOptions.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.PolicyStatus.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.Constraint.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.Database.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.Layout.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.table.TableInfo.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.UfsStatus.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.WorkerInfo.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
internalGetMutableMapField(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
internalGetValueMap() - Static method in enum alluxio.grpc.BackupState
 
internalGetValueMap() - Static method in enum alluxio.grpc.Bits
 
internalGetValueMap() - Static method in enum alluxio.grpc.BlockMasterInfoField
 
internalGetValueMap() - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
 
internalGetValueMap() - Static method in enum alluxio.grpc.CommandType
 
internalGetValueMap() - Static method in enum alluxio.grpc.ConfigStatus
 
internalGetValueMap() - Static method in enum alluxio.grpc.ErrorType
 
internalGetValueMap() - Static method in enum alluxio.grpc.JobMasterMetaCommand
 
internalGetValueMap() - Static method in enum alluxio.grpc.JobProgressReportFormat
 
internalGetValueMap() - Static method in enum alluxio.grpc.JobSource
 
internalGetValueMap() - Static method in enum alluxio.grpc.JobType
 
internalGetValueMap() - Static method in enum alluxio.grpc.JournalDomain
 
internalGetValueMap() - Static method in enum alluxio.grpc.LoadDescendantPType
 
internalGetValueMap() - Static method in enum alluxio.grpc.LoadMetadataPType
 
internalGetValueMap() - Static method in enum alluxio.grpc.MasterInfoField
 
internalGetValueMap() - Static method in enum alluxio.grpc.MetaCommand
 
internalGetValueMap() - Static method in enum alluxio.grpc.MetricType
 
internalGetValueMap() - Static method in enum alluxio.grpc.NodeState
 
internalGetValueMap() - Static method in enum alluxio.grpc.OperationType
 
internalGetValueMap() - Static method in enum alluxio.grpc.PAclAction
 
internalGetValueMap() - Static method in enum alluxio.grpc.PAclEntryType
 
internalGetValueMap() - Static method in enum alluxio.grpc.QuorumServerState
 
internalGetValueMap() - Static method in enum alluxio.grpc.ReadPType
 
internalGetValueMap() - Static method in enum alluxio.grpc.RequestType
 
internalGetValueMap() - Static method in enum alluxio.grpc.SaslMessageType
 
internalGetValueMap() - Static method in enum alluxio.grpc.Scope
 
internalGetValueMap() - Static method in enum alluxio.grpc.ServiceType
 
internalGetValueMap() - Static method in enum alluxio.grpc.SetAclAction
 
internalGetValueMap() - Static method in enum alluxio.grpc.Status
 
internalGetValueMap() - Static method in enum alluxio.grpc.SyncPointStatus
 
internalGetValueMap() - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
 
internalGetValueMap() - Static method in enum alluxio.grpc.table.PrincipalType
 
internalGetValueMap() - Static method in enum alluxio.grpc.table.TableInfo.TableType
 
internalGetValueMap() - Static method in enum alluxio.grpc.TaskStatus
 
internalGetValueMap() - Static method in enum alluxio.grpc.TtlAction
 
internalGetValueMap() - Static method in enum alluxio.grpc.UfsPMode
 
internalGetValueMap() - Static method in enum alluxio.grpc.WorkerInfoField
 
internalGetValueMap() - Static method in enum alluxio.grpc.WorkerRange
 
internalGetValueMap() - Static method in enum alluxio.grpc.WritePType
 
internalGetValueMap() - Static method in enum alluxio.grpc.XAttrPropagationStrategy
 
internalGetValueMap() - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
internalGetValueMap() - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
internalGetValueMap() - Static method in enum alluxio.proto.journal.File.PSetAclAction
 
internalGetValueMap() - Static method in enum alluxio.proto.journal.File.PTtlAction
 
internalGetValueMap() - Static method in enum alluxio.proto.journal.File.UfsMode
 
internalGetValueMap() - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
 
internalGetValueMap() - Static method in enum alluxio.proto.journal.Job.PJobState
 
internalGetValueMap() - Static method in enum alluxio.proto.shared.Acl.AclAction
 
internalGetValueMap() - Static method in enum alluxio.proto.shared.Acl.AclEntryType
 
internalGetValueMap() - Static method in enum alluxio.proto.status.Status.PStatus
 
InternalOperationContext - Class in alluxio.master.file.contexts
Used for wiring call-tracking to non-rpc requests.
InternalOperationContext() - Constructor for class alluxio.master.file.contexts.InternalOperationContext
Creates a new internal operation context.
InternalRuntimeException - Exception in alluxio.exception.runtime
Exception representing an internal error.
InternalRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.InternalRuntimeException
Constructor.
InternalRuntimeException(String) - Constructor for exception alluxio.exception.runtime.InternalRuntimeException
Constructor.
InternalRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.InternalRuntimeException
Constructor.
interruptCycleTicking() - Method in class alluxio.master.StateLockManager
 
intersect(Interval) - Method in class alluxio.master.predicate.interval.Interval
 
intersect(IntervalSet) - Method in class alluxio.master.predicate.interval.IntervalSet
 
intersect(List<IntervalSet>) - Static method in class alluxio.master.predicate.interval.IntervalUtils
 
intersectionList() - Method in class alluxio.DefaultStorageTierAssoc
 
intersectionList() - Method in interface alluxio.StorageTierAssoc
 
Interval - Class in alluxio.master.predicate.interval
This represents a time interval, start (inclusive) to end (exclusive).
IntervalSet - Class in alluxio.master.predicate.interval
This represents a set of time intervals.
IntervalSet(List<Interval>) - Constructor for class alluxio.master.predicate.interval.IntervalSet
Creates a new instance.
IntervalSet(Interval) - Constructor for class alluxio.master.predicate.interval.IntervalSet
Creates a new instance, with a single Interval.
IntervalUtils - Class in alluxio.master.predicate.interval
This represents a time interval.
intoByteArray(byte[]) - Static method in class alluxio.util.io.ChannelAdapters
Adapts a byte array to be the destination of a WritableByteChannel.
intoByteArray(byte[], int, int) - Static method in class alluxio.util.io.ChannelAdapters
Adapts a byte array to be the destination of a WritableByteChannel.
intoByteBuf(ByteBuf) - Static method in class alluxio.util.io.ChannelAdapters
todo(bowen): implement.
intoByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.ChannelAdapters
Adapts a ByteBuffer to be the destination of a WritableByteChannel.
intValue() - Method in enum alluxio.jnifuse.constants.Errno
 
INVALID_ARGUMENT - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_ARGUMENT - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_ARGUMENT_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
InvalidArgument indicates client specified an invalid argument.
INVALID_BUCKET_NAME - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_BUCKET_NAME - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_CLUSTER_ID - Static variable in class alluxio.master.meta.DefaultMetaMaster
Value to be used for the cluster ID when not assigned.
INVALID_CONTENT_HASH - Static variable in class alluxio.underfs.UfsFileStatus
 
INVALID_CONTINUATION_TOKEN - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_CONTINUATION_TOKEN - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_FILE_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_FINGERPRINT - Static variable in class alluxio.underfs.Fingerprint
 
INVALID_IDENTIFIER - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_IDENTIFIER - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_MODE - Static variable in class alluxio.Constants
 
INVALID_MOUNT_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_NESTED_BUCKET_NAME - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_PART - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_PART - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_PART_ORDER - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_PART_ORDER - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_REQUEST - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_REQUEST - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_RESULT - Static variable in class alluxio.master.file.meta.SyncCheck.SyncResult
 
INVALID_S3_RANGE_SPEC - Static variable in class alluxio.s3.S3RangeSpec
 
INVALID_TAG - Static variable in class alluxio.s3.S3ErrorCode
 
INVALID_TAG - Static variable in class alluxio.s3.S3ErrorCode.Name
 
INVALID_UFS_FINGERPRINT - Static variable in class alluxio.Constants
 
INVALID_WORKER_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_WORKER_ID - Static variable in class alluxio.worker.JobWorkerIdRegistry
The default value to initialize job worker id, the job worker id generated by job master will never be the same as this value.
InvalidArgumentException - Exception in alluxio.exception.status
Exception indicating that a client specified an invalid argument.
InvalidArgumentException(String) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentException(Throwable) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentException(String, Throwable) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that a client specified an invalid argument.
InvalidArgumentRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.InvalidArgumentRuntimeException
Constructor.
InvalidArgumentRuntimeException(String) - Constructor for exception alluxio.exception.runtime.InvalidArgumentRuntimeException
Constructor.
InvalidArgumentRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.InvalidArgumentRuntimeException
Constructor.
invalidate(Predicate<PageInfo>) - Method in interface alluxio.client.file.cache.CacheManager
Invalidate the pages that match the given predicate.
invalidate(Predicate<PageInfo>) - Method in class alluxio.client.file.cache.LocalCacheManager
 
invalidate(AlluxioURI) - Method in class alluxio.client.file.MetadataCache
Invalidates the cache of path.
invalidate(String) - Method in class alluxio.client.file.MetadataCache
Invalidates the cache of path.
invalidate(long) - Method in class alluxio.master.file.meta.LazyUfsBlockLocationCache
 
invalidate(long) - Method in interface alluxio.master.file.meta.UfsBlockLocationCache
Invalidates the UFS locations for the block.
invalidate(Integer) - Method in class alluxio.StreamCache
 
invalidateAll() - Method in class alluxio.client.file.MetadataCache
Invalidates all the cache.
invalidateListingCache(String) - Method in class alluxio.worker.dora.DoraMetaManager
Invalidates the listing cache of a given path.
invalidateListingCacheOfParent(String) - Method in class alluxio.worker.dora.DoraMetaManager
Invalidates the listing cache of its parent of a given path.
InvalidationSyncCacheBench - Class in alluxio.invalidation.cache
 
InvalidationSyncCacheBench() - Constructor for class alluxio.invalidation.cache.InvalidationSyncCacheBench
 
InvalidationSyncCacheBench.FileStructure - Class in alluxio.invalidation.cache
 
InvalidationSyncCacheBench.ThreadState - Class in alluxio.invalidation.cache
 
InvalidFileSizeException - Exception in alluxio.exception
The exception thrown when the file of a size is invalid.
InvalidFileSizeException(String) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified detail message.
InvalidFileSizeException(String, Throwable) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified detail message and cause.
InvalidFileSizeException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidFileSizeException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
InvalidPathException - Exception in alluxio.exception
The exception thrown when the path in Alluxio is invalid.
InvalidPathException(String) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified detail message.
InvalidPathException(String, Throwable) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified detail message and cause.
InvalidPathException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidPathException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
InvalidVersionParsingException - Exception in alluxio.wire
Thrown when the version is invalid and thus not parsable.
InvalidVersionParsingException(int, int...) - Constructor for exception alluxio.wire.InvalidVersionParsingException
Constructs a new exception with details of the invalid version.
InvalidWorkerStateException - Exception in alluxio.exception
The exception thrown when a worker is in an invalid state, i.e.
InvalidWorkerStateException(String) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified detail message.
InvalidWorkerStateException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified exception message and multiple parameters.
invoke(ForkJoinTask<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Performs the given task, returning its result upon completion.
invoke() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Commences performing this task, awaits its completion if necessary, and returns its result, or throws an (unchecked) RuntimeException or Error if the underlying computation did so.
invoke(Logger, CompletableFuture<T>, String, String, StreamObserver<T>, Object...) - Static method in class alluxio.RpcUtils
Calls the given method and handled exception.
invoke(Logger, ListenableFuture<T>, String, String, StreamObserver<T>, Object...) - Static method in class alluxio.RpcUtils
Calls the given method and handled exception.
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(ForkJoinTask<?>...) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(Collection<T>) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Forks all tasks in the specified collection, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.master.AlluxioExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.master.AlluxioExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAll(List<Callable<T>>, long) - Static method in class alluxio.util.CommonUtils
Executes the given callables, waiting for them to complete (or time out).
invokeAll(ExecutorService, List<Callable<T>>, long) - Static method in class alluxio.util.CommonUtils
Executes the given callables, waiting for them to complete (or time out).
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAny(Collection<? extends Callable<T>>) - Method in class alluxio.master.AlluxioExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.master.AlluxioExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
io() - Method in class alluxio.examples.Performance.HdfsWorker
Creates IO utilization.
IOTaskResult - Class in alluxio.stress.worker
Task result for the UFS I/O test.
IOTaskResult() - Constructor for class alluxio.stress.worker.IOTaskResult
An empty constructor.
IOTaskResult(List<IOTaskResult.Point>, List<String>) - Constructor for class alluxio.stress.worker.IOTaskResult
The constructor used for serialization.
IOTaskResult.IOMode - Enum in alluxio.stress.worker
The IO mode, either READ or WRITE.
IOTaskResult.Point - Class in alluxio.stress.worker
An object representation of a successful I/O operation to the UFS.
IOTaskSummary - Class in alluxio.stress.worker
The summary for the UFS I/O throughput test.
IOTaskSummary() - Constructor for class alluxio.stress.worker.IOTaskSummary
Used for deserialization.
IOTaskSummary(IOTaskResult) - Constructor for class alluxio.stress.worker.IOTaskSummary
 
IOTaskSummary.GraphGenerator - Class in alluxio.stress.worker
A graph generator for the statistics collected.
IOTaskSummary.SpeedStat - Class in alluxio.stress.worker
An object representation of all the statistics we need from this I/O test.
is64Bit() - Static method in class alluxio.jnifuse.utils.Environment
 
is64Bit() - Static method in class alluxio.util.OSUtils
 
IS_CACHEABLE_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
IS_COMPLETED_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
IS_DIRECTORY_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
IS_DIRECTORY_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
IS_MOUNT_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
IS_PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
IS_SKIP_FIELD_NUMBER - Static variable in class alluxio.grpc.RouteFailure
 
isAarch64() - Static method in class alluxio.jnifuse.utils.Environment
 
isAbsentSince(AlluxioURI, long) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
isAbsentSince(AlluxioURI, long) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
isAbsentSince(AlluxioURI, long) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Returns true if the given path was found to be absent since absentSince, according to this cache.
isAbsolute() - Method in class alluxio.AlluxioURI
Tells whether or not the AlluxioURI is absolute.
isAbsolute() - Method in class alluxio.uri.StandardURI
 
isAbsolute() - Method in interface alluxio.uri.URI
Tells whether or not the URI is absolute.
isActive() - Method in class alluxio.client.block.BlockWorkerInfo
Whether this worker is active or not.
isAddressReachable(String, int, int) - Static method in class alluxio.util.CommonUtils
Validates whether a network address is reachable.
isAix() - Static method in class alluxio.jnifuse.utils.Environment
 
isAIX() - Static method in class alluxio.util.OSUtils
 
isAlluxioRunning(String) - Static method in class alluxio.util.ShellUtils
Checks whether an Alluxio service is running.
isAlluxioServer() - Static method in class alluxio.util.CommonUtils
NOTE: This method is fragile and does not work with our testing infrastructure.
isAncestorOf(AlluxioURI) - Method in class alluxio.AlluxioURI
Returns true if the current AlluxioURI is an ancestor of another AlluxioURI.
isAnyDir() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_DIR.
isAnyDirWithTier() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_DIR within the specified tier.
isAnyMedium() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_MEDIUM.
isAnyTier() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_TIER.
isAsyncCacheRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isAsyncRestoreEnabled() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
isAsyncWriteEnabled() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
ISATOMICWRITE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
isAuthenticated() - Method in class alluxio.grpc.GrpcService
 
isAuthenticated(AwsAuthInfo) - Method in interface alluxio.s3.auth.Authenticator
Check if the AwsAuthInfo is legal.
isAuthenticated(AwsAuthInfo) - Method in class alluxio.s3.auth.PassAllAuthenticator
 
isAuthenticated() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
isAuthenticationEnabled(AlluxioConfiguration) - Static method in class alluxio.proxy.s3.S3RestUtils
Checks if authentication is enabled.
isAuthenticationEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if authentication is enabled.
isAuthorizationEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if authorization is enabled.
isBackup() - Method in class alluxio.master.backcompat.Journal
 
isBackupDelegationEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check back delegation is enabled.
isBlockLost(long) - Method in interface alluxio.master.block.BlockMaster
 
isBlockLost(long) - Method in class alluxio.master.block.DefaultBlockMaster
 
isBlockStoreRocks() - Static method in class alluxio.util.FeatureUtils
Utility to check the master block metastore is rocks.
isBuiltIn() - Method in class alluxio.conf.PropertyKey
 
isCache() - Method in enum alluxio.client.ReadType
 
isCache() - Method in enum alluxio.client.WriteType
 
isCacheable() - Method in class alluxio.client.file.URIStatus
 
isCacheable() - Method in class alluxio.master.file.contexts.CreateFileContext
 
isCacheable() - Method in class alluxio.master.file.meta.InodeFile
 
isCacheable() - Method in interface alluxio.master.file.meta.InodeFileView
 
isCacheable() - Method in class alluxio.master.file.meta.MutableInodeFile
 
isCacheable() - Method in class alluxio.wire.FileInfo
 
isCancel() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
isCancel() - Method in class alluxio.worker.netty.ReadRequestContext
 
isCanceled() - Method in class alluxio.client.block.stream.GrpcBlockingStream
 
isCancelled() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns true if this CompletableFuture was cancelled before it completed normally.
isCancelled() - Method in class alluxio.concurrent.jsr.ForkJoinTask
 
isCancelled() - Method in interface alluxio.master.file.contexts.CallTracker
 
isCancelled() - Method in class alluxio.master.file.contexts.GrpcCallTracker
 
isCancelled() - Method in class alluxio.master.file.RpcContext
 
isCephFS(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isCFT(String) - Static method in class alluxio.util.EnvironmentUtils
Checks whether the given user data belongs to an instance launched through CFT.
isClosed() - Method in class alluxio.AbstractClient
 
isClosed() - Method in class alluxio.client.block.stream.GrpcBlockingStream
 
isClosed() - Method in class alluxio.client.file.DelegatingFileSystem
 
isClosed() - Method in interface alluxio.client.file.FileSystem
If there are operations currently running and close is called concurrently the behavior is undefined.
isClosed() - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
isClosed() - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
isClosed() - Method in interface alluxio.Client
 
isClosed() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
isClosed() - Method in class alluxio.fuse.file.FuseFileInStream
 
isClosed() - Method in class alluxio.fuse.file.FuseFileOutStream
 
isClosed() - Method in interface alluxio.fuse.file.FuseFileStream
 
isClosed() - Method in class alluxio.fuse.file.FusePositionReader
 
isClosed() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
isClosed() - Method in class alluxio.resource.CloseableResource
 
isClosed() - Method in class alluxio.worker.block.io.BlockReader
 
isClosed() - Method in interface alluxio.worker.DataServer
Checks if the DataServer is closed.
isClosed() - Method in class alluxio.worker.dora.OpenFileHandle
Check if this handle is already closed.
isClosed() - Method in class alluxio.worker.dora.PagedFileReader
 
isClosed() - Method in class alluxio.worker.grpc.GrpcDataServer
 
isClosed() - Method in class alluxio.worker.netty.NettyDataServer
 
isClusterAggregated() - Method in class alluxio.metrics.MetricKey
 
isCollection(Object) - Static method in class alluxio.util.CommonUtils
 
isComplete() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
isCompleted() - Method in class alluxio.client.file.URIStatus
 
isCompleted() - Method in class alluxio.master.file.meta.InodeFile
 
isCompleted() - Method in interface alluxio.master.file.meta.InodeFileView
 
isCompleted() - Method in class alluxio.master.file.meta.MutableInodeFile
 
isCompleted() - Method in class alluxio.wire.BackupStatus
 
isCompleted() - Method in class alluxio.wire.FileInfo
 
isCompletedAbnormally() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns true if this task threw an exception or was cancelled.
isCompletedExceptionally() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns true if this CompletableFuture completed exceptionally, in any way.
isCompletedNormally() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns true if this task completed without throwing an exception and was not cancelled.
isConnected() - Method in class alluxio.AbstractClient
 
isConnected() - Method in interface alluxio.Client
Returns the connected status of the client.
isCurrentPassDone() - Method in class alluxio.master.job.CopyJob
 
isCurrentPassDone() - Method in class alluxio.master.job.DoraLoadJob
 
isCurrentPassDone() - Method in class alluxio.master.job.LoadJob
 
isCurrentPassDone() - Method in class alluxio.master.job.MoveJob
 
isCurrentPassDone() - Method in interface alluxio.scheduler.job.Job
Check whether the current pass is finished.
isDailyBackupEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check daily backup is enabled.
isDataCacheEnabled() - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
isDataCacheEnabled() - Method in class alluxio.client.file.options.FileSystemOptions
 
isDataOnPreferredWorker() - Method in class alluxio.cli.fs.command.FileLocation
If data locates at the preferred worker.
isDataReaderActive() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
isDebugEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isDebugEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isDefault() - Method in class alluxio.security.authorization.AclEntry
 
ISDEFAULT_FIELD_NUMBER - Static variable in class alluxio.grpc.PAcl
 
ISDEFAULT_FIELD_NUMBER - Static variable in class alluxio.grpc.PAclEntry
 
ISDEFAULT_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
ISDEFAULT_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AclEntry
 
ISDEFAULTEMPTY_FIELD_NUMBER - Static variable in class alluxio.grpc.PAcl
 
isDeleted() - Method in class alluxio.master.file.meta.Inode
 
isDeleted() - Method in interface alluxio.master.file.meta.InodeView
 
isDeleted() - Method in class alluxio.master.file.meta.MutableInode
 
isDeprecated(PropertyKey) - Static method in class alluxio.conf.PropertyKey
Returns whether or not the given property key is marked as deprecated.
isDeprecated(String) - Static method in class alluxio.conf.PropertyKey
 
isDirectChildrenLoaded() - Method in class alluxio.master.file.meta.InodeDirectory
 
isDirectChildrenLoaded() - Method in interface alluxio.master.file.meta.InodeDirectoryView
 
isDirectChildrenLoaded() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
isDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isDirectory() - Method in class alluxio.master.file.meta.Inode
 
isDirectory() - Method in interface alluxio.master.file.meta.InodeView
 
isDirectory() - Method in class alluxio.master.file.meta.MutableInode
 
isDirectory(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isDirectory(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
isDirectory() - Method in class alluxio.underfs.UfsStatus
 
isDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a directory exists in under file system.
isDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isDirectoryInSync(AlluxioURI) - Method in class alluxio.master.file.UfsSyncChecker
Based on directories for which UfsSyncChecker.checkDirectory(InodeDirectory, AlluxioURI) was called, this method returns whether any un-synced entries were found.
isDocker() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the docker deployment environment.
isDomainSocketAccessible(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
 
isDomainSocketSupported(WorkerNetAddress) - Static method in class alluxio.util.network.NettyUtils
 
isDone() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns true if completed in any fashion: normally, exceptionally, or via cancellation.
isDone() - Method in class alluxio.concurrent.jsr.ForkJoinTask
 
isDone() - Method in class alluxio.master.job.AbstractJob
 
isDone() - Method in interface alluxio.scheduler.job.Job
Check whether the job is finished.
isDoneListing() - Method in class alluxio.master.file.contexts.ListStatusContext
 
isDoneUnsafe() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
isDoneUnsafe() - Method in class alluxio.worker.grpc.WriteRequestContext
 
isDoneUnsafe() - Method in class alluxio.worker.netty.ReadRequestContext
 
isDoneUnsafe() - Method in class alluxio.worker.netty.WriteRequestContext
 
isDoraCacheEnabled() - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
isDoraCacheEnabled() - Method in class alluxio.client.file.options.FileSystemOptions
 
isDynamic() - Method in class alluxio.conf.PropertyKey
 
isEC2() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the EC2 deployment environment.
isEmbeddedJournal() - Static method in class alluxio.util.FeatureUtils
Utility to check the master journal type is embedded journal.
isEmpty() - Method in class alluxio.collections.ConcurrentHashSet
 
isEmpty() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
isEmpty() - Method in class alluxio.collections.DelegatingSet
 
isEmpty() - Method in class alluxio.collections.UnmodifiableArrayList
 
isEmpty() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
isEmpty() - Method in interface alluxio.master.file.meta.InodeLockList
 
isEmpty() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
isEmpty() - Method in interface alluxio.master.journal.JournalSystem
Returns whether the journal is formatted and has not had any entries written to it yet.
isEmpty() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
isEmpty() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
isEmpty() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
isEmpty() - Method in class alluxio.security.authorization.DefaultAccessControlList
Returns true if the default ACL is empty.
isEmpty() - Method in class alluxio.util.executor.ControllableQueue
 
ISEMPTY_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
isEMR(String) - Static method in class alluxio.util.EnvironmentUtils
Checks whether the given user data belongs to an instance launched through EMR.
isEnabled() - Method in class alluxio.master.block.BlockMasterFactory
 
isEnabled() - Method in class alluxio.master.file.FileSystemMasterFactory
 
isEnabled() - Method in class alluxio.master.journal.JournalMasterFactory
 
isEnabled() - Method in interface alluxio.master.MasterFactory
 
isEnabled() - Method in class alluxio.master.meta.MetaMasterFactory
 
isEnabled() - Method in class alluxio.master.metrics.MetricsMasterFactory
 
isEnsureAtomic() - Method in class alluxio.underfs.options.CreateOptions
 
isEof() - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
isEof() - Method in class alluxio.worker.netty.ReadRequestContext
 
isErrorEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isErrorEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isEvictionAllowed() - Method in class alluxio.worker.block.AllocateOptions
 
isExistingDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isExistingDirectory(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
isExistingDirectory(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isExistingDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a directory exists in under file system.
isExistingDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isFailed() - Method in class alluxio.wire.BackupStatus
 
isFatalError(Throwable) - Static method in class alluxio.util.CommonUtils
 
isFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isFile() - Method in class alluxio.master.file.meta.Inode
 
isFile() - Method in interface alluxio.master.file.meta.InodeView
 
isFile() - Method in class alluxio.master.file.meta.MutableInode
 
isFile(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
isFile(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
isFile(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
isFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isFile() - Method in class alluxio.underfs.UfsStatus
 
isFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a file exists in under file system.
isFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for checking file is actual file.
isFinished() - Method in enum alluxio.job.wire.Status
 
isFinished() - Method in class alluxio.wire.BackupStatus
 
isFirstFile() - Method in class alluxio.underfs.UfsLoadResult
 
isFolder() - Method in class alluxio.client.file.URIStatus
 
isFolder() - Method in class alluxio.wire.FileInfo
 
isForceLocation() - Method in class alluxio.worker.block.AllocateOptions
 
isFormatted() - Method in interface alluxio.master.journal.JournalSystem
 
isFormatted() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
isFormatted() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
isFormatted() - Method in class alluxio.master.journal.ufs.UfsJournal
 
isFormatted() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
isFormatted() - Method in interface alluxio.master.journalv0.Journal
 
isFormatted() - Method in class alluxio.master.journalv0.ufs.UfsJournal
 
isFreeBSD() - Static method in class alluxio.jnifuse.utils.Environment
 
isFromUFSFallBack() - Method in class alluxio.client.file.URIStatus
 
isFuseInstalled() - Static method in class alluxio.fuse.AlluxioFuseUtils
Checks whether fuse is installed in local file system.
isGcs(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isGoogleComputeEngine() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the Google compute engine deployment environment.
isGrpcServerServing() - Method in class alluxio.master.service.rpc.RpcServerService
 
isGrpcServingAsLeader() - Method in class alluxio.master.MasterProcess
 
isHaMode(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
isHdfs(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isHdfsScheme(String) - Static method in class alluxio.cli.ValidationUtils
Checks if a path is HDFS.
isHealthy(BlockMasterClient) - Method in class alluxio.client.block.BlockMasterClientPool
 
isHealthy() - Method in interface alluxio.client.block.stream.BlockWorkerClient
 
isHealthy(BlockWorkerClient) - Method in class alluxio.client.block.stream.BlockWorkerClientPool
Checks whether a client is healthy.
isHealthy() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
isHealthy(FileSystemMasterClient) - Method in class alluxio.client.file.FileSystemMasterClientPool
 
isHealthy() - Method in class alluxio.grpc.GrpcChannel
 
isHealthy() - Method in class alluxio.master.job.CopyJob
 
isHealthy() - Method in class alluxio.master.job.DoraLoadJob
 
isHealthy() - Method in class alluxio.master.job.LoadJob
 
isHealthy() - Method in class alluxio.master.job.MoveJob
 
isHealthy(Channel) - Method in class alluxio.network.netty.NettyChannelPool
Checks whether a channel is healthy.
isHealthy(T) - Method in class alluxio.resource.DynamicResourcePool
Checks whether a resource is healthy or not.
isHealthy() - Method in interface alluxio.scheduler.job.Job
Check whether the job is healthy.
isHealthy() - Method in class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
Determines whether the system is healthy from all the metrics it has collected.
isHeartbeat() - Method in class alluxio.util.proto.ProtoMessage
 
isHidden() - Method in class alluxio.conf.PropertyKey
 
isHiveLayout(Layout) - Static method in class alluxio.table.ProtoUtils
 
isIgnoredSiteProperty() - Method in class alluxio.conf.PropertyKey
 
isIncludeRealContentHash() - Method in class alluxio.underfs.options.GetStatusOptions
 
isInfoEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isInfoEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isInitialized() - Method in class alluxio.grpc.ActionInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.ActionInfo
 
isInitialized() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.AddPolicyPOptions
 
isInitialized() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.AddPolicyPRequest
 
isInitialized() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.AddPolicyPResponse
 
isInitialized() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.AddQuorumServerRequest
 
isInitialized() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.AsyncCacheRequest
 
isInitialized() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.AsyncCacheResponse
 
isInitialized() - Method in class alluxio.grpc.BackupPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.BackupPOptions
 
isInitialized() - Method in class alluxio.grpc.BackupPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.BackupPRequest
 
isInitialized() - Method in class alluxio.grpc.BackupPStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.BackupPStatus
 
isInitialized() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.BackupStatusPRequest
 
isInitialized() - Method in class alluxio.grpc.Block.Builder
 
isInitialized() - Method in class alluxio.grpc.Block
 
isInitialized() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
isInitialized() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
isInitialized() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
isInitialized() - Method in class alluxio.grpc.BlockIdList.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockIdList
 
isInitialized() - Method in class alluxio.grpc.BlockInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockInfo
 
isInitialized() - Method in class alluxio.grpc.BlockLocation.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockLocation
 
isInitialized() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockMasterInfo
 
isInitialized() - Method in class alluxio.grpc.BlockStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockStatus
 
isInitialized() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
isInitialized() - Method in class alluxio.grpc.BlockStoreLocationProto
 
isInitialized() - Method in class alluxio.grpc.BuildVersion.Builder
 
isInitialized() - Method in class alluxio.grpc.BuildVersion
 
isInitialized() - Method in class alluxio.grpc.CacheRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CacheRequest
 
isInitialized() - Method in class alluxio.grpc.CacheResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CacheResponse
 
isInitialized() - Method in class alluxio.grpc.CancelPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CancelPOptions
 
isInitialized() - Method in class alluxio.grpc.CancelPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CancelPRequest
 
isInitialized() - Method in class alluxio.grpc.CancelPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CancelPResponse
 
isInitialized() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
isInitialized() - Method in class alluxio.grpc.CancelTaskCommand
 
isInitialized() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckAccessPOptions
 
isInitialized() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckAccessPRequest
 
isInitialized() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckAccessPResponse
 
isInitialized() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
isInitialized() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
isInitialized() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
isInitialized() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckpointPOptions
 
isInitialized() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckpointPResponse
 
isInitialized() - Method in class alluxio.grpc.CheckRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckRequest
 
isInitialized() - Method in class alluxio.grpc.CheckResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CheckResponse
 
isInitialized() - Method in class alluxio.grpc.Chunk.Builder
 
isInitialized() - Method in class alluxio.grpc.Chunk
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsPRequest
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsPResponse
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsRequest
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ClearMetricsResponse
 
isInitialized() - Method in class alluxio.grpc.ClientMetrics.Builder
 
isInitialized() - Method in class alluxio.grpc.ClientMetrics
 
isInitialized() - Method in class alluxio.grpc.CmdProgress.Builder
 
isInitialized() - Method in class alluxio.grpc.CmdProgress
 
isInitialized() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
isInitialized() - Method in class alluxio.grpc.CmdStatusBlock
 
isInitialized() - Method in class alluxio.grpc.CmdSummary.Builder
 
isInitialized() - Method in class alluxio.grpc.CmdSummary
 
isInitialized() - Method in class alluxio.grpc.Command.Builder
 
isInitialized() - Method in class alluxio.grpc.Command
 
isInitialized() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CommitBlockPOptions
 
isInitialized() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CommitBlockPRequest
 
isInitialized() - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CommitBlockPResponse
 
isInitialized() - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CompleteFilePOptions
 
isInitialized() - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CompleteFilePRequest
 
isInitialized() - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CompleteFilePResponse
 
isInitialized() - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
isInitialized() - Method in class alluxio.grpc.ConfigCheckReport
 
isInitialized() - Method in class alluxio.grpc.ConfigProperties.Builder
 
isInitialized() - Method in class alluxio.grpc.ConfigProperties
 
isInitialized() - Method in class alluxio.grpc.ConfigProperty.Builder
 
isInitialized() - Method in class alluxio.grpc.ConfigProperty
 
isInitialized() - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CopyJobPOptions
 
isInitialized() - Method in class alluxio.grpc.CopyRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CopyRequest
 
isInitialized() - Method in class alluxio.grpc.CopyResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CopyResponse
 
isInitialized() - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
isInitialized() - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
isInitialized() - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
isInitialized() - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateFilePOptions
 
isInitialized() - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateFilePRequest
 
isInitialized() - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.CreateFilePResponse
 
isInitialized() - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
isInitialized() - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
isInitialized() - Method in class alluxio.grpc.DeletePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.DeletePOptions
 
isInitialized() - Method in class alluxio.grpc.DeletePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.DeletePRequest
 
isInitialized() - Method in class alluxio.grpc.DeletePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.DeletePResponse
 
isInitialized() - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.ErrorInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.ErrorInfo
 
isInitialized() - Method in class alluxio.grpc.ExistsPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ExistsPOptions
 
isInitialized() - Method in class alluxio.grpc.ExistsPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ExistsPRequest
 
isInitialized() - Method in class alluxio.grpc.ExistsPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ExistsPResponse
 
isInitialized() - Method in class alluxio.grpc.File.Builder
 
isInitialized() - Method in class alluxio.grpc.File
 
isInitialized() - Method in class alluxio.grpc.FileBlockInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.FileBlockInfo
 
isInitialized() - Method in class alluxio.grpc.FileFailure.Builder
 
isInitialized() - Method in class alluxio.grpc.FileFailure
 
isInitialized() - Method in class alluxio.grpc.FileInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.FileInfo
 
isInitialized() - Method in class alluxio.grpc.FileSystemCommand.Builder
 
isInitialized() - Method in class alluxio.grpc.FileSystemCommand
 
isInitialized() - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.FileSystemCommandOptions
 
isInitialized() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
isInitialized() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
isInitialized() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
isInitialized() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
isInitialized() - Method in class alluxio.grpc.FreePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.FreePOptions
 
isInitialized() - Method in class alluxio.grpc.FreePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.FreePRequest
 
isInitialized() - Method in class alluxio.grpc.FreePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.FreePResponse
 
isInitialized() - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.FreeWorkerRequest
 
isInitialized() - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.FreeWorkerResponse
 
isInitialized() - Method in class alluxio.grpc.FsOpPId.Builder
 
isInitialized() - Method in class alluxio.grpc.FsOpPId
 
isInitialized() - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetActionInfoOptions
 
isInitialized() - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetActionInfoRequest
 
isInitialized() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetActionInfoResponse
 
isInitialized() - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
isInitialized() - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
isInitialized() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
isInitialized() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
isInitialized() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
isInitialized() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
isInitialized() - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
isInitialized() - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
isInitialized() - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
isInitialized() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
isInitialized() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
isInitialized() - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
isInitialized() - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusOptions
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusRequest
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetCmdStatusResponse
 
isInitialized() - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetConfigHashPOptions
 
isInitialized() - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetConfigHashPResponse
 
isInitialized() - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetConfigReportPOptions
 
isInitialized() - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetConfigReportPResponse
 
isInitialized() - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetConfigurationPOptions
 
isInitialized() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetConfigurationPResponse
 
isInitialized() - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetFileInfoPOptions
 
isInitialized() - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetFileInfoPRequest
 
isInitialized() - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetFileInfoPResponse
 
isInitialized() - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetFilePathPRequest
 
isInitialized() - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetFilePathPResponse
 
isInitialized() - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
isInitialized() - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
isInitialized() - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
isInitialized() - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobProgressPRequest
 
isInitialized() - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobProgressPResponse
 
isInitialized() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
isInitialized() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
isInitialized() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusPOptions
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusPRequest
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetJobStatusPResponse
 
isInitialized() - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMasterIdPOptions
 
isInitialized() - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMasterIdPRequest
 
isInitialized() - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMasterIdPResponse
 
isInitialized() - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
isInitialized() - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
isInitialized() - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMetricsPOptions
 
isInitialized() - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMetricsPResponse
 
isInitialized() - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMountIdPRequest
 
isInitialized() - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMountIdPResponse
 
isInitialized() - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMountTablePRequest
 
isInitialized() - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetMountTablePResponse
 
isInitialized() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
isInitialized() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
isInitialized() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
isInitialized() - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetNodeStatePRequest
 
isInitialized() - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetNodeStatePResponse
 
isInitialized() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
isInitialized() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
isInitialized() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
isInitialized() - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
isInitialized() - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
isInitialized() - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
isInitialized() - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
isInitialized() - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
isInitialized() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
isInitialized() - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
isInitialized() - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
isInitialized() - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
isInitialized() - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
isInitialized() - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
isInitialized() - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
isInitialized() - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
isInitialized() - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
isInitialized() - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetStatusPOptions
 
isInitialized() - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetStatusPRequest
 
isInitialized() - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetStatusPResponse
 
isInitialized() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
isInitialized() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
isInitialized() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
isInitialized() - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
isInitialized() - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
isInitialized() - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
isInitialized() - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
isInitialized() - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
isInitialized() - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
isInitialized() - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
isInitialized() - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
isInitialized() - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
isInitialized() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
isInitialized() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
isInitialized() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
isInitialized() - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
isInitialized() - Method in class alluxio.grpc.InconsistentProperties.Builder
 
isInitialized() - Method in class alluxio.grpc.InconsistentProperties
 
isInitialized() - Method in class alluxio.grpc.InconsistentProperty.Builder
 
isInitialized() - Method in class alluxio.grpc.InconsistentProperty
 
isInitialized() - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
isInitialized() - Method in class alluxio.grpc.InconsistentPropertyValues
 
isInitialized() - Method in class alluxio.grpc.JobCommand.Builder
 
isInitialized() - Method in class alluxio.grpc.JobCommand
 
isInitialized() - Method in class alluxio.grpc.JobDescription.Builder
 
isInitialized() - Method in class alluxio.grpc.JobDescription
 
isInitialized() - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
isInitialized() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
isInitialized() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
isInitialized() - Method in class alluxio.grpc.JobInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.JobInfo
 
isInitialized() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
isInitialized() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
isInitialized() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
isInitialized() - Method in class alluxio.grpc.JobMasterStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.JobMasterStatus
 
isInitialized() - Method in class alluxio.grpc.JobProgress.Builder
 
isInitialized() - Method in class alluxio.grpc.JobProgress
 
isInitialized() - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.JobProgressPOptions
 
isInitialized() - Method in class alluxio.grpc.JobServiceSummary.Builder
 
isInitialized() - Method in class alluxio.grpc.JobServiceSummary
 
isInitialized() - Method in class alluxio.grpc.JobStatusBlock.Builder
 
isInitialized() - Method in class alluxio.grpc.JobStatusBlock
 
isInitialized() - Method in class alluxio.grpc.JobUnused.Builder
 
isInitialized() - Method in class alluxio.grpc.JobUnused
 
isInitialized() - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
isInitialized() - Method in class alluxio.grpc.JobWorkerHealth
 
isInitialized() - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.JournalQueryRequest
 
isInitialized() - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
isInitialized() - Method in class alluxio.grpc.ListAllPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ListAllPOptions
 
isInitialized() - Method in class alluxio.grpc.ListAllPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ListAllPRequest
 
isInitialized() - Method in class alluxio.grpc.ListAllPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ListAllPResponse
 
isInitialized() - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ListPolicyPOptions
 
isInitialized() - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ListPolicyPRequest
 
isInitialized() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ListPolicyPResponse
 
isInitialized() - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
isInitialized() - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
isInitialized() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
isInitialized() - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
isInitialized() - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
isInitialized() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
isInitialized() - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ListStatusPOptions
 
isInitialized() - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ListStatusPRequest
 
isInitialized() - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ListStatusPResponse
 
isInitialized() - Method in class alluxio.grpc.LoadFileFailure.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadFileFailure
 
isInitialized() - Method in class alluxio.grpc.LoadFileRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadFileRequest
 
isInitialized() - Method in class alluxio.grpc.LoadFileResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadFileResponse
 
isInitialized() - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadJobPOptions
 
isInitialized() - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadMetadataPOptions
 
isInitialized() - Method in class alluxio.grpc.LoadRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadRequest
 
isInitialized() - Method in class alluxio.grpc.LoadResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.LoadResponse
 
isInitialized() - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
isInitialized() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
isInitialized() - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
isInitialized() - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
isInitialized() - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
isInitialized() - Method in class alluxio.grpc.MasterInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.MasterInfo
 
isInitialized() - Method in class alluxio.grpc.MasterVersion.Builder
 
isInitialized() - Method in class alluxio.grpc.MasterVersion
 
isInitialized() - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
isInitialized() - Method in class alluxio.grpc.MessagingRequestHeader
 
isInitialized() - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
isInitialized() - Method in class alluxio.grpc.MessagingResponseHeader
 
isInitialized() - Method in class alluxio.grpc.Metric.Builder
 
isInitialized() - Method in class alluxio.grpc.Metric
 
isInitialized() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
isInitialized() - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
isInitialized() - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
isInitialized() - Method in class alluxio.grpc.MetricValue.Builder
 
isInitialized() - Method in class alluxio.grpc.MetricValue
 
isInitialized() - Method in class alluxio.grpc.MountPointInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.MountPointInfo
 
isInitialized() - Method in class alluxio.grpc.MountPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.MountPOptions
 
isInitialized() - Method in class alluxio.grpc.MountPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.MountPRequest
 
isInitialized() - Method in class alluxio.grpc.MountPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.MountPResponse
 
isInitialized() - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.MoveBlockRequest
 
isInitialized() - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.MoveBlockResponse
 
isInitialized() - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.MoveJobPOptions
 
isInitialized() - Method in class alluxio.grpc.MoveRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.MoveRequest
 
isInitialized() - Method in class alluxio.grpc.MoveResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.MoveResponse
 
isInitialized() - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.NeedsSyncRequest
 
isInitialized() - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.NeedsSyncResponse
 
isInitialized() - Method in class alluxio.grpc.NetAddress.Builder
 
isInitialized() - Method in class alluxio.grpc.NetAddress
 
isInitialized() - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
isInitialized() - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
isInitialized() - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
isInitialized() - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.OpenFilePOptions
 
isInitialized() - Method in class alluxio.grpc.PAcl.Builder
 
isInitialized() - Method in class alluxio.grpc.PAcl
 
isInitialized() - Method in class alluxio.grpc.PAclEntry.Builder
 
isInitialized() - Method in class alluxio.grpc.PAclEntry
 
isInitialized() - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.PersistCommandOptions
 
isInitialized() - Method in class alluxio.grpc.PersistFile.Builder
 
isInitialized() - Method in class alluxio.grpc.PersistFile
 
isInitialized() - Method in class alluxio.grpc.PMode.Builder
 
isInitialized() - Method in class alluxio.grpc.PMode
 
isInitialized() - Method in class alluxio.grpc.PolicyInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.PolicyInfo
 
isInitialized() - Method in class alluxio.grpc.PolicyStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.PolicyStatus
 
isInitialized() - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
isInitialized() - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
isInitialized() - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
isInitialized() - Method in class alluxio.grpc.ProxyStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.ProxyStatus
 
isInitialized() - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.QuorumServerInfo
 
isInitialized() - Method in class alluxio.grpc.ReadRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ReadRequest
 
isInitialized() - Method in class alluxio.grpc.ReadResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ReadResponse
 
isInitialized() - Method in class alluxio.grpc.RegisterCommand.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterCommand
 
isInitialized() - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
isInitialized() - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
isInitialized() - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
isInitialized() - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
isInitialized() - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
isInitialized() - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
isInitialized() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterMasterPOptions
 
isInitialized() - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterMasterPRequest
 
isInitialized() - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterMasterPResponse
 
isInitialized() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
isInitialized() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
isInitialized() - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
isInitialized() - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RemoveBlockRequest
 
isInitialized() - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RemoveBlockResponse
 
isInitialized() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
isInitialized() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
isInitialized() - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
isInitialized() - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
isInitialized() - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
isInitialized() - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RemovePolicyPOptions
 
isInitialized() - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RemovePolicyPRequest
 
isInitialized() - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RemovePolicyPResponse
 
isInitialized() - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
isInitialized() - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
isInitialized() - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
isInitialized() - Method in class alluxio.grpc.RenamePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RenamePOptions
 
isInitialized() - Method in class alluxio.grpc.RenamePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RenamePRequest
 
isInitialized() - Method in class alluxio.grpc.RenamePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RenamePResponse
 
isInitialized() - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
isInitialized() - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
isInitialized() - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
isInitialized() - Method in class alluxio.grpc.RetryInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.RetryInfo
 
isInitialized() - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ReverseResolvePRequest
 
isInitialized() - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ReverseResolvePResponse
 
isInitialized() - Method in class alluxio.grpc.Route.Builder
 
isInitialized() - Method in class alluxio.grpc.Route
 
isInitialized() - Method in class alluxio.grpc.RouteFailure.Builder
 
isInitialized() - Method in class alluxio.grpc.RouteFailure
 
isInitialized() - Method in class alluxio.grpc.RunPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.RunPOptions
 
isInitialized() - Method in class alluxio.grpc.RunPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.RunPRequest
 
isInitialized() - Method in class alluxio.grpc.RunPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.RunPResponse
 
isInitialized() - Method in class alluxio.grpc.RunTaskCommand.Builder
 
isInitialized() - Method in class alluxio.grpc.RunTaskCommand
 
isInitialized() - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.S3SyntaxOptions
 
isInitialized() - Method in class alluxio.grpc.SaslMessage.Builder
 
isInitialized() - Method in class alluxio.grpc.SaslMessage
 
isInitialized() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
isInitialized() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
isInitialized() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
isInitialized() - Method in class alluxio.grpc.SetAclPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.SetAclPOptions
 
isInitialized() - Method in class alluxio.grpc.SetAclPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.SetAclPRequest
 
isInitialized() - Method in class alluxio.grpc.SetAclPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.SetAclPResponse
 
isInitialized() - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.SetAttributePOptions
 
isInitialized() - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.SetAttributePRequest
 
isInitialized() - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.SetAttributePResponse
 
isInitialized() - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
isInitialized() - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
isInitialized() - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
isInitialized() - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
isInitialized() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
isInitialized() - Method in class alluxio.grpc.SnapshotData.Builder
 
isInitialized() - Method in class alluxio.grpc.SnapshotData
 
isInitialized() - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
isInitialized() - Method in class alluxio.grpc.SnapshotMetadata
 
isInitialized() - Method in class alluxio.grpc.StatusSummary.Builder
 
isInitialized() - Method in class alluxio.grpc.StatusSummary
 
isInitialized() - Method in class alluxio.grpc.StopJobPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.StopJobPRequest
 
isInitialized() - Method in class alluxio.grpc.StopJobPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.StopJobPResponse
 
isInitialized() - Method in class alluxio.grpc.StorageList.Builder
 
isInitialized() - Method in class alluxio.grpc.StorageList
 
isInitialized() - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.SubmitJobPRequest
 
isInitialized() - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.SubmitJobPResponse
 
isInitialized() - Method in class alluxio.grpc.SubmitOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.SubmitOptions
 
isInitialized() - Method in class alluxio.grpc.SubmitRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.SubmitRequest
 
isInitialized() - Method in class alluxio.grpc.SubmitResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.SubmitResponse
 
isInitialized() - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
isInitialized() - Method in class alluxio.grpc.table.AllOrNoneSet
 
isInitialized() - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
isInitialized() - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
isInitialized() - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
isInitialized() - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
isInitialized() - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
isInitialized() - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
isInitialized() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
isInitialized() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
isInitialized() - Method in class alluxio.grpc.table.Constraint.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Constraint
 
isInitialized() - Method in class alluxio.grpc.table.Database.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Database
 
isInitialized() - Method in class alluxio.grpc.table.Date.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Date
 
isInitialized() - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.DateColumnStatsData
 
isInitialized() - Method in class alluxio.grpc.table.Decimal.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Decimal
 
isInitialized() - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
isInitialized() - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
isInitialized() - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
isInitialized() - Method in class alluxio.grpc.table.Domain.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Domain
 
isInitialized() - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
isInitialized() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
isInitialized() - Method in class alluxio.grpc.table.EquatableValueSet
 
isInitialized() - Method in class alluxio.grpc.table.FieldSchema.Builder
 
isInitialized() - Method in class alluxio.grpc.table.FieldSchema
 
isInitialized() - Method in class alluxio.grpc.table.FileStatistics.Builder
 
isInitialized() - Method in class alluxio.grpc.table.FileStatistics
 
isInitialized() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
isInitialized() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
isInitialized() - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
isInitialized() - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
isInitialized() - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
isInitialized() - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
isInitialized() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
isInitialized() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
isInitialized() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
isInitialized() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
isInitialized() - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetTablePRequest
 
isInitialized() - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetTablePResponse
 
isInitialized() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
isInitialized() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
isInitialized() - Method in class alluxio.grpc.table.Layout.Builder
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.Storage
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
isInitialized() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
isInitialized() - Method in class alluxio.grpc.table.Layout
 
isInitialized() - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
isInitialized() - Method in class alluxio.grpc.table.LayoutSpec
 
isInitialized() - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.LongColumnStatsData
 
isInitialized() - Method in class alluxio.grpc.table.Partition.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Partition
 
isInitialized() - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
isInitialized() - Method in class alluxio.grpc.table.PartitionSpec
 
isInitialized() - Method in class alluxio.grpc.table.Range.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Range
 
isInitialized() - Method in class alluxio.grpc.table.RangeSet.Builder
 
isInitialized() - Method in class alluxio.grpc.table.RangeSet
 
isInitialized() - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.ReadTablePRequest
 
isInitialized() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.ReadTablePResponse
 
isInitialized() - Method in class alluxio.grpc.table.Schema.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Schema
 
isInitialized() - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
isInitialized() - Method in class alluxio.grpc.table.StringColumnStatsData
 
isInitialized() - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
isInitialized() - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
isInitialized() - Method in class alluxio.grpc.table.SyncStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.table.SyncStatus
 
isInitialized() - Method in class alluxio.grpc.table.TableInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.table.TableInfo
 
isInitialized() - Method in class alluxio.grpc.table.Transformation.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Transformation
 
isInitialized() - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.table.TransformJobInfo
 
isInitialized() - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.table.TransformTablePRequest
 
isInitialized() - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.table.TransformTablePResponse
 
isInitialized() - Method in class alluxio.grpc.table.Value.Builder
 
isInitialized() - Method in class alluxio.grpc.table.Value
 
isInitialized() - Method in class alluxio.grpc.TierList.Builder
 
isInitialized() - Method in class alluxio.grpc.TierList
 
isInitialized() - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
isInitialized() - Method in class alluxio.grpc.TransferLeaderMessage
 
isInitialized() - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
isInitialized() - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
isInitialized() - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
isInitialized() - Method in class alluxio.grpc.TransportMessage.Builder
 
isInitialized() - Method in class alluxio.grpc.TransportMessage
 
isInitialized() - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.TriggerPolicyRequest
 
isInitialized() - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.TriggerPolicyResponse
 
isInitialized() - Method in class alluxio.grpc.UfsFileStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.UfsFileStatus
 
isInitialized() - Method in class alluxio.grpc.UfsInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.UfsInfo
 
isInitialized() - Method in class alluxio.grpc.UfsReadOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.UfsReadOptions
 
isInitialized() - Method in class alluxio.grpc.UfsStatus.Builder
 
isInitialized() - Method in class alluxio.grpc.UfsStatus
 
isInitialized() - Method in class alluxio.grpc.UnmountPOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.UnmountPOptions
 
isInitialized() - Method in class alluxio.grpc.UnmountPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.UnmountPRequest
 
isInitialized() - Method in class alluxio.grpc.UnmountPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.UnmountPResponse
 
isInitialized() - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
isInitialized() - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
isInitialized() - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.UpdateMountPRequest
 
isInitialized() - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.UpdateMountPResponse
 
isInitialized() - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
isInitialized() - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
isInitialized() - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
isInitialized() - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
isInitialized() - Method in class alluxio.grpc.WorkerIdentity.Builder
 
isInitialized() - Method in class alluxio.grpc.WorkerIdentity
 
isInitialized() - Method in class alluxio.grpc.WorkerInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.WorkerInfo
 
isInitialized() - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
isInitialized() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
isInitialized() - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
isInitialized() - Method in class alluxio.grpc.WorkerNetAddress
 
isInitialized() - Method in class alluxio.grpc.WriteOptions.Builder
 
isInitialized() - Method in class alluxio.grpc.WriteOptions
 
isInitialized() - Method in class alluxio.grpc.WriteRequest.Builder
 
isInitialized() - Method in class alluxio.grpc.WriteRequest
 
isInitialized() - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
isInitialized() - Method in class alluxio.grpc.WriteRequestCommand
 
isInitialized() - Method in class alluxio.grpc.WriteResponse.Builder
 
isInitialized() - Method in class alluxio.grpc.WriteResponse
 
isInitialized() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
isInitialized() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
isInitialized() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
isInitialized() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.Response
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
isInitialized() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
isInitialized() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.RenameEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.SetAclEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.StringPairEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
isInitialized() - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
isInitialized() - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Job.FileFilter
 
isInitialized() - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
isInitialized() - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
isInitialized() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
isInitialized() - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
isInitialized() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
isInitialized() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
isInitialized() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
isInitialized() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
isInitialized() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
isInitialized() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
isInitialized() - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
isInitialized() - Method in class alluxio.proto.meta.Block.BlockLocation
 
isInitialized() - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
isInitialized() - Method in class alluxio.proto.meta.Block.BlockMeta
 
isInitialized() - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
isInitialized() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
isInitialized() - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
isInitialized() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
isInitialized() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
isInitialized() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
isInitialized() - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
isInitialized() - Method in class alluxio.proto.shared.Acl.AclActions
 
isInitialized() - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
isInitialized() - Method in class alluxio.proto.shared.Acl.AclEntry
 
isInitialized() - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
isInitialized() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
isInodeStoreRocks() - Static method in class alluxio.util.FeatureUtils
Utility to check the master inode metastore is rocks.
isInSafeMode() - Method in class alluxio.master.AlluxioMasterProcess
 
isInSafeMode() - Method in class alluxio.master.DefaultSafeModeManager
 
isInSafeMode() - Method in class alluxio.master.meta.DefaultMetaMaster
 
isInSafeMode() - Method in interface alluxio.master.meta.MetaMaster
 
isInSafeMode() - Method in interface alluxio.master.SafeModeManager
 
isInterrupted(Throwable) - Static method in class alluxio.util.ExceptionUtils
 
isInTier(String) - Method in class alluxio.util.webui.UIFileBlockInfo
Is in tier boolean.
isIsObjectStore() - Method in class alluxio.underfs.UfsLoadResult
 
isJobFinished() - Method in class alluxio.master.job.plan.PlanCoordinator
 
isKubernetes() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the k8s deployment environment.
isLeader() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
ISLEADER_FIELD_NUMBER - Static variable in class alluxio.grpc.QuorumServerInfo
 
isLeaseExpired(AlluxioEtcdClient.Lease) - Method in class alluxio.membership.AlluxioEtcdClient
Check with etcd if a lease is already expired.
isLinux() - Static method in class alluxio.util.OSUtils
 
isLocal(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isLocalAddress(String, int) - Static method in class alluxio.util.network.NetworkAddressUtils
 
isLocalBlockCloseRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCompleteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCreateRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCreateResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockOpenRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockOpenResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalFilesystem(String) - Static method in class alluxio.util.URIUtils
 
isLocalHost(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
 
isMac() - Static method in class alluxio.jnifuse.utils.Environment
 
isMacFuse() - Static method in class alluxio.fuse.AlluxioFuseUtils
 
isMacOS() - Static method in class alluxio.util.OSUtils
 
isMasterAuditLoggingEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check master audit logging is enabled.
isMetadataCacheEnabled() - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
isMetadataCacheEnabled() - Method in class alluxio.client.file.options.FileSystemOptions
 
isMetadataLoad() - Method in class alluxio.master.file.contexts.CompleteFileContext
 
isMetadataLoad() - Method in class alluxio.master.file.contexts.CreatePathContext
 
isMetadataLoad() - Method in class alluxio.master.file.contexts.DeleteContext
 
isMetadataLoad() - Method in class alluxio.master.file.contexts.SetAttributeContext
 
isMetricSinkServing() - Method in class alluxio.master.MasterProcess
 
isMountingPoint(String, String[]) - Static method in class alluxio.util.ShellUtils
Checks whether a path is the mounting point of a RAM disk volume.
isMountPoint() - Method in class alluxio.client.file.URIStatus
 
isMountPoint() - Method in class alluxio.master.file.contexts.CreatePathContext
 
isMountPoint() - Method in class alluxio.master.file.meta.InodeDirectory
 
isMountPoint() - Method in interface alluxio.master.file.meta.InodeDirectoryView
 
isMountPoint(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
 
isMountPoint() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
isMountPoint() - Method in class alluxio.wire.FileInfo
 
ISMULTIPARTUPLOAD_FIELD_NUMBER - Static variable in class alluxio.grpc.S3SyntaxOptions
 
isMultipartUploadEnabled() - Method in class alluxio.underfs.options.CreateOptions
 
isNested(String) - Method in class alluxio.conf.PropertyKey
 
isNettyEpollAvailable() - Static method in class alluxio.util.network.NettyUtils
 
isNondeterministic() - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
 
isObjectStorage() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isObjectStorage() - Method in class alluxio.underfs.BaseUnderFileSystem
 
isObjectStorage() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isObjectStorage() - Method in interface alluxio.underfs.UnderFileSystem
 
isObjectStorage() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isOpen() - Method in class alluxio.client.block.stream.GrpcBlockingStream
 
isOpen() - Method in class alluxio.master.block.WorkerRegisterContext
Checks whether the stream is still open.
isOpen() - Method in class alluxio.worker.block.io.BlockReadableChannel
 
isOpenBSD() - Static method in class alluxio.jnifuse.utils.Environment
 
isOperationComplete(OperationId) - Method in class alluxio.master.file.meta.InodeTree
Whether given operation is still cached in retry-cache.
isOperationComplete(OperationId) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Whether given operation is still cached in retry-cache.
isOss(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isOverwrite() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
isOverwrite() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
isOverwrite() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
isOverwrite() - Method in class alluxio.job.plan.persist.PersistConfig
 
isPacketReaderActive() - Method in class alluxio.worker.netty.ReadRequestContext
 
isPacketWriterActive() - Method in class alluxio.worker.netty.WriteRequestContext
 
isPageStoreEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check page store is enabled.
isPartialListing() - Method in class alluxio.master.file.contexts.ListStatusContext
 
isPathAbsolute() - Method in class alluxio.AlluxioURI
Tells whether or not the path component of the AlluxioURI is absolute.
isPersisted() - Method in class alluxio.client.file.URIStatus
 
isPersisted() - Method in class alluxio.master.file.contexts.CreatePathContext
 
isPersisted() - Method in class alluxio.master.file.meta.Inode
 
isPersisted() - Method in interface alluxio.master.file.meta.InodeView
 
isPersisted() - Method in class alluxio.master.file.meta.MutableInode
 
isPersisted() - Method in class alluxio.wire.FileInfo
 
isPersisted() - Method in class alluxio.worker.netty.BlockReadRequest
 
isPersistenceBlacklistEmpty() - Static method in class alluxio.util.FeatureUtils
Utility to check persistence black list is empty.
isPinned() - Method in class alluxio.client.file.URIStatus
 
isPinned() - Method in class alluxio.master.file.meta.Inode
 
isPinned() - Method in interface alluxio.master.file.meta.InodeView
 
isPinned() - Method in class alluxio.master.file.meta.MutableInode
 
isPinned() - Method in class alluxio.util.webui.UIFileInfo
Is pinned boolean.
isPinned() - Method in class alluxio.wire.FileInfo
 
isPositionShort() - Method in class alluxio.wire.BlockReadRequest
 
isPosRead(ClientIOOperation) - Static method in enum alluxio.stress.client.ClientIOOperation
 
isPowerPC() - Static method in class alluxio.jnifuse.utils.Environment
 
isPrimary() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
isPrimary() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
isPromote() - Method in enum alluxio.client.AlluxioStorageType
 
isPromote() - Method in enum alluxio.client.ReadType
 
isPromote() - Method in class alluxio.wire.BlockReadRequest
 
isPromote() - Method in class alluxio.worker.netty.BlockReadRequest
 
isQuiescent() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if all worker threads are currently idle.
isQuotaEnabled() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
isRead(ClientIOOperation) - Static method in enum alluxio.stress.client.ClientIOOperation
 
isReadOnly() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
isReadOnly() - Method in class alluxio.fuse.file.FuseFileInStream
 
isReadOnly() - Method in class alluxio.fuse.file.FuseFileOutStream
 
isReadOnly() - Method in interface alluxio.fuse.file.FuseFileStream
 
isReadOnly() - Method in class alluxio.fuse.file.FusePositionReader
 
isReadOnly() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
isReadOnly() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isReadOnly() - Method in class alluxio.util.webui.UIMountPointInfo
Is readonly.
isReadRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isReadResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isReady() - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
isRecursive() - Method in class alluxio.master.file.contexts.CreatePathContext
 
isRecursive() - Method in class alluxio.underfs.options.DeleteOptions
 
isRecursive() - Method in class alluxio.underfs.options.ListOptions
 
isRegistered() - Method in class alluxio.master.block.meta.MasterWorkerInfo
isRejected(WorkerNetAddress) - Method in interface alluxio.master.block.BlockMaster
 
isRejected(WorkerNetAddress) - Method in class alluxio.master.block.DefaultBlockMaster
 
isReleasable() - Method in interface alluxio.concurrent.jsr.ForkJoinPool.ManagedBlocker
Returns true if blocking is unnecessary.
isRemoved(String) - Static method in class alluxio.conf.PropertyKey
Returns whether or not a property key has been removed from use.
isResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isResultValid() - Method in class alluxio.master.file.meta.SyncCheck.SyncResult
 
isRetryable() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
ISRETRYABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.RetryInfo
 
isRoot() - Method in class alluxio.AlluxioURI
Tells whether or not the AlluxioURI is root.
isRoot(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Checks if a given payload is in a root of the DAG.
isRoot(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Checks if the path is the root.
isRoot(String) - Static method in class alluxio.util.io.PathUtils
Checks if the given path is the root.
isRootId(long) - Method in class alluxio.master.file.meta.InodeTree
 
isRunning() - Method in class alluxio.master.job.AbstractJob
 
isRunning() - Method in interface alluxio.scheduler.job.Job
Check whether the job is still running.
isS3(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isS390x() - Static method in class alluxio.jnifuse.utils.Environment
 
isSafeMode() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get if in safe mode.
ISSCANNING_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
isSecurityEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if security is enabled.
isSeekable() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isSeekable() - Method in class alluxio.underfs.BaseUnderFileSystem
 
isSeekable() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
isSeekable() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
isSeekable() - Method in interface alluxio.underfs.UnderFileSystem
Denotes if the under storage supports seeking.
isSeekable() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isSequential() - Method in class alluxio.job.workflow.composite.CompositeConfig
 
isServiceStopping() - Method in class alluxio.rocks.RocksStore
Checks whether the RocksDB is marked for exclusive access, so the operation should abort.
isServing() - Method in class alluxio.common.RpcPortHealthCheckClient
 
isServing() - Method in class alluxio.grpc.GrpcServer
 
isServing() - Method in interface alluxio.HealthCheckClient
 
isServing() - Method in class alluxio.master.LocalAlluxioMaster
 
isServing() - Method in class alluxio.master.MasterHealthCheckClient
 
isServing() - Method in class alluxio.master.service.rpc.RpcServerService
 
isServing() - Method in class alluxio.master.service.web.WebServerService
 
isServing() - Method in class alluxio.proxy.ProxyHealthCheckClient
 
isServing(String, int) - Static method in class alluxio.util.network.NetworkAddressUtils
 
isServingLeader() - Method in class alluxio.master.service.rpc.RpcServerService
 
isServingLeader() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
isServingStandby() - Method in class alluxio.master.service.rpc.RpcServerService
 
isServingStandby() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
isSet(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Checks if the configuration contains a value for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Checks if there is a value set for the given key.
isSet(PropertyKey) - Static method in class alluxio.conf.Configuration
Checks if the configuration contains a value for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
isSet(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isSetByUser(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
 
isSetByUser(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
isSetByUser(PropertyKey) - Static method in class alluxio.conf.Configuration
Checks if the configuration contains a value for the given key that is set by a user.
isSetByUser(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
isSetByUser(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isShared() - Method in class alluxio.util.webui.UIMountPointInfo
Is shared.
isShouldSync() - Method in class alluxio.master.file.meta.SyncCheck
 
isShutdown() - Method in interface alluxio.client.block.stream.BlockWorkerClient
 
isShutdown() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
isShutdown() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if this pool has been shut down.
isShutdown() - Method in class alluxio.grpc.GrpcChannel
 
isShutdown() - Method in class alluxio.master.AlluxioExecutorService
 
isShutdown() - Method in class alluxio.metrics.InstrumentedExecutorService
 
isShutdown() - Method in class alluxio.util.executor.ControllableScheduler
 
isSignPayload() - Method in class alluxio.s3.signature.SignatureInfo
 
isSnapshotting() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
isSolaris() - Static method in class alluxio.jnifuse.utils.Environment
 
isSpecialCommand(AlluxioURI) - Method in class alluxio.cli.FuseShell
Checks if the given uri contains Fuse special command.
isSpecialCommandEnabled() - Method in class alluxio.fuse.options.FuseOptions.Builder
 
isStarted() - Static method in class alluxio.metrics.MetricsSystem
 
isStarted() - Method in class alluxio.util.JvmPauseMonitor
 
isStartedWorkers() - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
isStopped() - Method in class alluxio.master.AlluxioMasterProcess
Indicates if all master resources have been successfully released when stopping.
isStorageDirAccessible(String) - Static method in class alluxio.util.io.FileUtils
Checks if a storage directory path is accessible.
isStore() - Method in enum alluxio.client.AlluxioStorageType
 
isSuspended() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
 
isSuspended() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
isSuspended() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
isSyncPersist() - Method in enum alluxio.client.UnderStorageType
 
isTemporary() - Method in class alluxio.client.file.CacheContext
 
isTemporaryConnectionToken() - Method in interface alluxio.underfs.UnderFileSystem
Denotes if the under storage is in the temporary connection token mode.
isTemporaryFileName(String) - Static method in class alluxio.util.io.PathUtils
Determines whether the given path is a temporary file name generated by Alluxio.
isTerminated() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class alluxio.master.AlluxioExecutorService
 
isTerminated() - Method in class alluxio.metrics.InstrumentedExecutorService
 
isTerminated() - Method in class alluxio.util.executor.ControllableScheduler
 
isTerminating() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if the process of termination has commenced but not yet completed.
isThrough() - Method in enum alluxio.client.WriteType
 
ISTHROWABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.MessagingResponseHeader
 
isTraceEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isTraceEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isTruncated() - Method in class alluxio.client.file.ListStatusPartialResult
 
isTruncated() - Method in class alluxio.master.file.contexts.ListStatusContext
 
isTruncated() - Method in class alluxio.proxy.s3.ListPartsResult
 
isTruncated() - Method in class alluxio.s3.ListBucketResult
 
isTruncated() - Method in class alluxio.underfs.UfsLoadResult
 
ISTRUNCATED_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPResponse
 
isTruncatedMessageException(IOException) - Static method in class alluxio.util.proto.ProtoUtils
Checks whether the exception is an InvalidProtocolBufferException thrown because of a truncated message.
isTtlEnabled() - Method in class alluxio.client.file.cache.CacheManagerOptions
 
isUfsFallbackEnabled() - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
isUfsFallbackEnabled() - Method in class alluxio.client.file.options.FileSystemOptions
 
isUnique() - Method in class alluxio.collections.IndexDefinition
 
isUnix() - Static method in class alluxio.jnifuse.utils.Environment
 
isUnsafeDirectPersistEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check unsafe direct persistence is enabled.
isUpdateCheckEnabled() - Method in class alluxio.fuse.options.FuseOptions.Builder
 
isUseRaftJournal() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get if Alluxio uses raft journal.
isUseZookeeper() - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get if zookeeper is running.
isValid(String) - Static method in class alluxio.conf.PropertyKey
 
isValid() - Method in interface alluxio.master.journalv0.JournalReader
Checks to see if the journal checkpoint has not been updated.
isValid() - Method in class alluxio.master.journalv0.ufs.UfsJournalReader
 
isValid() - Method in class alluxio.master.predicate.interval.Interval
 
isValid() - Method in class alluxio.master.predicate.interval.IntervalSet
 
isValid(String) - Static method in class alluxio.metrics.MetricKey
 
isValid() - Method in class alluxio.s3.S3RangeSpec
 
isValid() - Method in class alluxio.underfs.Fingerprint
Checks if the fingerprint object was generated from an INVALID_UFS_FINGERPRINT.
isValid() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
isVerificationEnabled() - Method in class alluxio.master.job.CopyJob
Is verification enabled.
isVerificationEnabled() - Method in class alluxio.master.job.LoadJob
Is verification enabled.
isVerificationEnabled() - Method in class alluxio.master.job.MoveJob
Is verification enabled.
isVersion2() - Method in class alluxio.s3.ListBucketResult
 
isWarnEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isWarnEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isWeb(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isWebServing() - Method in class alluxio.master.MasterProcess
 
isWindows() - Static method in class alluxio.jnifuse.utils.Environment
 
isWindows() - Static method in class alluxio.util.OSUtils
 
isWritable() - Method in class alluxio.master.journal.ufs.UfsJournal
 
isWrite() - Method in enum alluxio.master.file.meta.InodeTree.LockPattern
 
isWriteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isZookeeperEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check Zookeeper is enabled.
isZookeeperMode() - Method in class alluxio.hadoop.AbstractFileSystem
Deprecated.
in 1.6.0, directly infer the value from PropertyKey.ZOOKEEPER_ENABLED configuration value. Determines if zookeeper should be used for the FileSystem. This method should only be used for AbstractFileSystem.initialize(java.net.URI, org.apache.hadoop.conf.Configuration).
isZookeeperMode() - Method in class alluxio.hadoop.FileSystem
 
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in class alluxio.client.file.DelegatingFileSystem
 
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in class alluxio.client.file.DoraCacheFileSystem
 
iterateStatus(AlluxioURI, Consumer<? super URIStatus>) - Method in interface alluxio.client.file.FileSystem
Performs a specific action on each URIStatus in the result of FileSystem.listStatus(alluxio.AlluxioURI).
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in interface alluxio.client.file.FileSystem
Performs a specific action on each URIStatus in the result of FileSystem.listStatus(alluxio.AlluxioURI).
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in interface alluxio.client.file.FileSystemMasterClient
Performs a specific action on each URIStatus in the result of FileSystemMasterClient.listStatus(alluxio.AlluxioURI, alluxio.grpc.ListStatusPOptions).
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
iterateStatus(AlluxioURI, ListStatusPOptions, Consumer<? super URIStatus>) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
iterator() - Method in class alluxio.collections.ConcurrentHashSet
 
iterator() - Method in class alluxio.collections.DelegatingSet
 
iterator() - Method in interface alluxio.collections.FieldIndex
Returns an iterator over the elements in this index.
iterator() - Method in class alluxio.collections.IndexedSet
Returns an iterator over the elements in this set.
iterator() - Method in class alluxio.collections.NonUniqueFieldIndex
 
iterator() - Method in class alluxio.collections.UniqueFieldIndex
 
iterator() - Method in class alluxio.collections.UnmodifiableArrayList
 
iterator() - Method in class alluxio.master.file.meta.LockedInodePathList
 
iterator() - Method in class alluxio.master.job.FileIterable
 
iterator() - Method in class alluxio.master.job.UfsFileIterable
 
iterator() - Method in class alluxio.master.transport.Listeners
 
iterator() - Method in class alluxio.util.executor.UniqueBlockingQueue
 

J

JacksonProtobufObjectMapperProvider - Class in alluxio.web
Custom context resolver for Jersey to handle JSON-to-Protobuf conversion.
JacksonProtobufObjectMapperProvider() - Constructor for class alluxio.web.JacksonProtobufObjectMapperProvider
Create ObjectMapper provider that handles protobuf.
JAVA_OPT_FLAG - Static variable in class alluxio.stress.BaseParameters
 
JAVA_VENDOR_NAME - Static variable in class alluxio.util.OSUtils
The java vendor name used in this platform.
JAVAX_WS_RS_CORE_MEDIA_TYPE - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
JmxServlet - Class in alluxio.web
Provides Read only web access to JMX.
JmxServlet() - Constructor for class alluxio.web.JmxServlet
 
JmxSink - Class in alluxio.metrics.sink
A sink which listens for new metrics and exposes them as namespaces MBeans.
JmxSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.JmxSink
Creates a new JmxSink with a Properties and MetricRegistry.
Job - Class in alluxio.proto.journal
 
Job<T extends Task<?>> - Interface in alluxio.scheduler.job
interface for job that can be scheduled by Alluxio scheduler.
Job.CopyJobEntry - Class in alluxio.proto.journal
next available id: 13
Job.CopyJobEntry.Builder - Class in alluxio.proto.journal
next available id: 13
Job.CopyJobEntryOrBuilder - Interface in alluxio.proto.journal
 
Job.FileFilter - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.FileFilter
Job.FileFilter.Builder - Class in alluxio.proto.journal
Protobuf type alluxio.proto.journal.FileFilter
Job.FileFilterOrBuilder - Interface in alluxio.proto.journal
 
Job.LoadJobEntry - Class in alluxio.proto.journal
next available id: 9
Job.LoadJobEntry.Builder - Class in alluxio.proto.journal
next available id: 9
Job.LoadJobEntryOrBuilder - Interface in alluxio.proto.journal
 
Job.MoveJobEntry - Class in alluxio.proto.journal
next available id: 13
Job.MoveJobEntry.Builder - Class in alluxio.proto.journal
next available id: 13
Job.MoveJobEntryOrBuilder - Interface in alluxio.proto.journal
 
Job.PJobState - Enum in alluxio.proto.journal
Journal entry messages for the block master.
JOB_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
JOB_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_COPY_FAIL - Static variable in class alluxio.master.job.CopyJob
 
JOB_COPY_SUCCESS - Static variable in class alluxio.master.job.CopyJob
 
JOB_DEFAULT_MASTER_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_MASTER_WEB_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_WORKER_DATA_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_WORKER_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_WORKER_WEB_PORT - Static variable in class alluxio.Constants
 
JOB_ERROR_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformJobInfo
 
JOB_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
JOB_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformJobInfo
 
JOB_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformTablePResponse
 
JOB_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
JOB_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
JOB_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
JOB_JOURNAL_NAME - Static variable in class alluxio.Constants
 
JOB_LOAD_BLOCK_COUNT - Static variable in class alluxio.master.job.LoadJob
 
JOB_LOAD_BLOCK_FAIL - Static variable in class alluxio.master.job.LoadJob
 
JOB_LOAD_BLOCK_SIZE - Static variable in class alluxio.master.job.LoadJob
 
JOB_LOAD_FAIL - Static variable in class alluxio.master.job.DoraLoadJob
 
JOB_LOAD_FAIL - Static variable in class alluxio.master.job.LoadJob
 
JOB_LOAD_FILE_COUNT - Static variable in class alluxio.master.job.DoraLoadJob
 
JOB_LOAD_FILE_FAIL - Static variable in class alluxio.master.job.DoraLoadJob
 
JOB_LOAD_FILE_SIZE - Static variable in class alluxio.master.job.DoraLoadJob
 
JOB_LOAD_RATE - Static variable in class alluxio.master.job.DoraLoadJob
 
JOB_LOAD_RATE - Static variable in class alluxio.master.job.LoadJob
 
JOB_LOAD_SUCCESS - Static variable in class alluxio.master.job.DoraLoadJob
 
JOB_LOAD_SUCCESS - Static variable in class alluxio.master.job.LoadJob
 
JOB_MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
JOB_MASTER_CLIENT_SERVICE = 10;
JOB_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
JOB_MASTER_CLIENT_THREADS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_CLIENT_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_FINISHED_JOB_PURGE_COUNT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_FINISHED_JOB_PURGE_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_FINISHED_JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_FINISHED_JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_JOB_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_JOB_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_LOST_MASTER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
JOB_MASTER_LOST_MASTER_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_LOST_MASTER_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_LOST_WORKER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
JOB_MASTER_LOST_WORKER_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_LOST_WORKER_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_MASTER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_MASTER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_MASTER_SERVICE_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_MASTER_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
JOB_MASTER_MASTER_SERVICE = 19;
JOB_MASTER_MASTER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
JOB_MASTER_MASTER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_MASTER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
JOB_MASTER_VALUE - Static variable in enum alluxio.grpc.JournalDomain
JOB_MASTER = 2;
JOB_MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WORKER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WORKER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WORKER_SERVICE_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_WORKER_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
JOB_MASTER_WORKER_SERVICE = 11;
JOB_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
JOB_MASTER_WORKER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WORKER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MOVE_FAIL - Static variable in class alluxio.master.job.MoveJob
 
JOB_MOVE_SUCCESS - Static variable in class alluxio.master.job.MoveJob
 
JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_SERVICE_MAX_RESPONSE_TIME_COUNT - Static variable in class alluxio.stress.StressConstants
 
JOB_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformJobInfo
 
JOB_WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_COMMAND_HANDLING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
JOB_WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_NAME - Static variable in class alluxio.Constants
 
JOB_WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_THREADPOOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_THREADPOOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_THROTTLING - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_THROTTLING - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JobAttempt - Class in alluxio.cli.fs.command.job
Abstract class for handling submission for a job.
JobAttempt(JobMasterClient, RetryPolicy) - Constructor for class alluxio.cli.fs.command.job.JobAttempt
 
JobCommand - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobCommand
JobCommand.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobCommand
JobCommandOrBuilder - Interface in alluxio.grpc
 
JobConfig - Interface in alluxio.job
A job configuration.
JOBCONFIG_FIELD_NUMBER - Static variable in class alluxio.grpc.RunPRequest
 
JOBCONFIG_FIELD_NUMBER - Static variable in class alluxio.grpc.RunTaskCommand
 
JobContext - Class in alluxio.client.job
A shared context that isolates all operations within the same JVM.
JOBCONTROLID_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdStatusBlock
 
JOBCONTROLID_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
JOBCONTROLID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusDetailedRequest
 
JOBCONTROLID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusRequest
 
JOBCONTROLID_FIELD_NUMBER - Static variable in class alluxio.grpc.SubmitResponse
 
JobDefinitionFactory() - Constructor for class alluxio.job.plan.batch.BatchedJobDefinition.JobDefinitionFactory
 
JobDescription - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.JobDescription
JobDescription - Class in alluxio.job
Job description that used as a key to identify the job in the scheduler.
JobDescription.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.JobDescription
JobDescription.Builder - Class in alluxio.job
Builder for JobDescription.
JOBDESCRIPTION_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobProgressPRequest
 
JOBDESCRIPTION_FIELD_NUMBER - Static variable in class alluxio.grpc.StopJobPRequest
 
JobDescriptionOrBuilder - Interface in alluxio.grpc
 
JobDoesNotExistException - Exception in alluxio.exception
The exception thrown when a job definition does not exist in Alluxio.
JobDoesNotExistException(String) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception with the specified detail message.
JobDoesNotExistException(long) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception saying the specified job ID does not exist.
JobFactory - Interface in alluxio.scheduler.job
Factory for creating job instances.
JobFactoryProducer - Class in alluxio.master.job
Producer for JobFactory.
JobGrpcClientUtils - Class in alluxio.client.job
Utils for interacting with the job service through a gRPC client.
JobHeartbeatPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobHeartbeatPOptions
JobHeartbeatPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobHeartbeatPOptions
JobHeartbeatPOptionsOrBuilder - Interface in alluxio.grpc
 
JobHeartbeatPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobHeartbeatPRequest
JobHeartbeatPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobHeartbeatPRequest
JobHeartbeatPRequestOrBuilder - Interface in alluxio.grpc
 
JobHeartbeatPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobHeartbeatPResponse
JobHeartbeatPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobHeartbeatPResponse
JobHeartbeatPResponseOrBuilder - Interface in alluxio.grpc
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.CancelPRequest
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.CancelTaskCommand
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobStatusDetailedPRequest
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobStatusPRequest
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.JobStatusBlock
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.RunPResponse
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.RunTaskCommand
 
JOBID_FIELD_NUMBER - Static variable in class alluxio.grpc.SubmitJobPResponse
 
JobIdGenerator - Class in alluxio.job.meta
This class generates unique job ids.
JobIdGenerator() - Constructor for class alluxio.job.meta.JobIdGenerator
Creates a new instance.
JOBIDONLY_FIELD_NUMBER - Static variable in class alluxio.grpc.ListAllPOptions
 
JOBIDS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListAllPResponse
 
JobInfo - Class in alluxio.grpc
next available id: 14
JobInfo - Interface in alluxio.job.wire
The Job Info.
JobInfo.Builder - Class in alluxio.grpc
next available id: 14
JOBINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobStatusDetailedPResponse
 
JOBINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobStatusPResponse
 
JobInfoOrBuilder - Interface in alluxio.grpc
 
JOBINFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListAllPResponse
 
JobMaster - Class in alluxio.master.job
The master that handles all job managing operations.
JobMaster(MasterContext, FileSystem, FileSystemContext, UfsManager) - Constructor for class alluxio.master.job.JobMaster
Creates a new instance of JobMaster.
JobMasterAuditContext - Class in alluxio.master.job
An audit context for job master.
JobMasterAuditContext(AsyncUserAccessAuditLogWriter) - Constructor for class alluxio.master.job.JobMasterAuditContext
Constructor of JobMasterAuditContext.
JobMasterClient - Interface in alluxio.client.job
Interface for job service clients to communicate with the job master.
JobMasterClient - Interface in alluxio.worker.job
Interface for job service workers to communicate with the job master.
JobMasterClient.Factory - Class in alluxio.client.job
Factory for JobMasterClient.
JobMasterClient.Factory - Class in alluxio.worker.job
Factory for JobMasterClient.
JobMasterClientContext - Class in alluxio.worker.job
Extension of MasterClientContext with defaults that make sense for job master clients.
JobMasterClientContext(ClientContext, MasterInquireClient, MasterInquireClient) - Constructor for class alluxio.worker.job.JobMasterClientContext
 
JobMasterClientContextBuilder - Class in alluxio.worker.job
A builder for instances of JobMasterClientContext.
JobMasterClientPool - Class in alluxio.client.job
Class for managing job master clients.
JobMasterClientPool(JobMasterClientContext) - Constructor for class alluxio.client.job.JobMasterClientPool
Creates a new job master client pool.
JobMasterClientRestServiceHandler - Class in alluxio.master.job
The REST service handler for job master.
JobMasterClientRestServiceHandler(ServletContext) - Constructor for class alluxio.master.job.JobMasterClientRestServiceHandler
Creates a new instance of JobMasterClientRestServiceHandler.
JobMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains job master service endpoints for job service clients.
JobMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains job master service endpoints for job service clients.
JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service JobMasterClientService.
JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service JobMasterClientService.
JobMasterClientServiceGrpc.JobMasterClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service JobMasterClientService.
JobMasterClientServiceGrpc.JobMasterClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service JobMasterClientService.
JobMasterClientServiceHandler - Class in alluxio.master.job
This class is a gRPC handler for job master RPCs invoked by a job service client.
JobMasterClientServiceHandler(JobMaster) - Constructor for class alluxio.master.job.JobMasterClientServiceHandler
Creates a new instance of JobMasterClientRestServiceHandler.
JobMasterClientServiceImplBase() - Constructor for class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceImplBase
 
jobMasterHeartbeat(long, JobMasterHeartbeatPOptions) - Method in class alluxio.master.job.JobMaster
Handles a heartbeat from a standby job master.
JobMasterHeartbeatPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterHeartbeatPOptions
JobMasterHeartbeatPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterHeartbeatPOptions
JobMasterHeartbeatPOptionsOrBuilder - Interface in alluxio.grpc
 
JobMasterHeartbeatPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterHeartbeatPRequest
JobMasterHeartbeatPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterHeartbeatPRequest
JobMasterHeartbeatPRequestOrBuilder - Interface in alluxio.grpc
 
JobMasterHeartbeatPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterHeartbeatPResponse
JobMasterHeartbeatPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterHeartbeatPResponse
JobMasterHeartbeatPResponseOrBuilder - Interface in alluxio.grpc
 
jobMasterHostConfigured(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
JOBMASTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobMasterPRequest
 
JobMasterInfo - Class in alluxio.master.meta
Job master information.
JobMasterInfo(long, Address) - Constructor for class alluxio.master.meta.JobMasterInfo
Creates a new instance of MasterInfo.
JobMasterMasterServiceGrpc - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
JobMasterMasterServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
JobMasterMasterServiceGrpc.JobMasterMasterServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service JobMasterMasterService.
JobMasterMasterServiceGrpc.JobMasterMasterServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service JobMasterMasterService.
JobMasterMasterServiceGrpc.JobMasterMasterServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service JobMasterMasterService.
JobMasterMasterServiceGrpc.JobMasterMasterServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service JobMasterMasterService.
JobMasterMasterServiceHandler - Class in alluxio.master.meta
This class is a gRPC handler for the primary job master to answer RPC from standby job masters.
JobMasterMasterServiceHandler(JobMaster) - Constructor for class alluxio.master.meta.JobMasterMasterServiceHandler
Creates a new instance of JobMasterMasterServiceHandler.
JobMasterMasterServiceImplBase() - Constructor for class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceImplBase
 
JobMasterMetaCommand - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.job.JobMasterMetaCommand
JobMasterProto - Class in alluxio.grpc
 
jobMasterRegister(long, RegisterJobMasterPOptions) - Method in class alluxio.master.job.JobMaster
Handles the register request from a standby job master.
JobMasterRpcHealthCheckClient - Class in alluxio.master.job
JobMasterHealthCheckClient check if job_master is serving RPC.
JobMasterRpcHealthCheckClient(InetSocketAddress, Supplier<RetryPolicy>, AlluxioConfiguration) - Constructor for class alluxio.master.job.JobMasterRpcHealthCheckClient
Creates a job_master health check client.
JobMasterStatus - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterStatus
JobMasterStatus.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobMasterStatus
JOBMASTERSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetAllMasterStatusPResponse
 
JobMasterStatusOrBuilder - Interface in alluxio.grpc
 
JobMasterSync - Class in alluxio.master.meta
If a job master is detected as a standby job master.
JobMasterSync(Address, RetryHandlingJobMasterMasterClient) - Constructor for class alluxio.master.meta.JobMasterSync
Creates a new instance of MetaMasterSync.
JobMasterWebServer - Class in alluxio.web
Job master web server.
JobMasterWebServer(String, InetSocketAddress, AlluxioJobMasterProcess) - Constructor for class alluxio.web.JobMasterWebServer
Creates a new instance of JobMasterWebServer.
JobMasterWorkerServiceGrpc - Class in alluxio.grpc
This interface contains job master service endpoints for job service workers.
JobMasterWorkerServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains job master service endpoints for job service workers.
JobMasterWorkerServiceGrpc.JobMasterWorkerServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service JobMasterWorkerService.
JobMasterWorkerServiceGrpc.JobMasterWorkerServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service JobMasterWorkerService.
JobMasterWorkerServiceGrpc.JobMasterWorkerServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service JobMasterWorkerService.
JobMasterWorkerServiceGrpc.JobMasterWorkerServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service JobMasterWorkerService.
JobMasterWorkerServiceHandler - Class in alluxio.master.job
This class is a gRPC handler for job master RPCs invoked by a job service worker.
JobMasterWorkerServiceHandler(JobMaster) - Constructor for class alluxio.master.job.JobMasterWorkerServiceHandler
Creates a new instance of JobMasterWorkerServiceHandler.
JobMasterWorkerServiceImplBase() - Constructor for class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceImplBase
 
JobMetaStore - Interface in alluxio.scheduler.job
Job meta store that store job information.
JobProgress - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobProgress
JobProgress.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobProgress
JOBPROGRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdProgress
 
JobProgressOrBuilder - Interface in alluxio.grpc
 
JobProgressPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.JobProgressPOptions
JobProgressPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.JobProgressPOptions
JobProgressPOptionsOrBuilder - Interface in alluxio.grpc
 
JobProgressReportFormat - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.JobProgressReportFormat
JobRequest - Interface in alluxio.job
A job request that can be used to create Job.
JobServerContext - Class in alluxio.job
The context is used by job to access master-side resources and information.
JobServerContext(FileSystem, FileSystemContext, UfsManager) - Constructor for class alluxio.job.JobServerContext
Creates a new instance of JobServerContext.
JobServiceMetricsCommand - Class in alluxio.cli.fsadmin.report
Prints job service metric information.
JobServiceMetricsCommand(JobMasterClient, PrintStream, String) - Constructor for class alluxio.cli.fsadmin.report.JobServiceMetricsCommand
Creates a new instance of JobServiceMetricsCommand.
JobServiceOutput - Class in alluxio.cli.fsadmin.report
An output class, describing the job service.
JobServiceOutput(List<JobMasterStatus>, List<JobWorkerHealth>, JobServiceSummary) - Constructor for class alluxio.cli.fsadmin.report.JobServiceOutput
Creates a new instance of JobServiceOutput.
JobServiceSummary - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobServiceSummary
JobServiceSummary - Class in alluxio.job.wire
Job service summary.
JobServiceSummary(List<JobInfo>) - Constructor for class alluxio.job.wire.JobServiceSummary
Constructs a new instance of JobServiceSummary from a collection of JobInfo it possesses.
JobServiceSummary(JobServiceSummary) - Constructor for class alluxio.job.wire.JobServiceSummary
Constructs a new instance of JobServiceSummary from a proto object.
JobServiceSummary.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobServiceSummary
JobServiceSummaryOrBuilder - Interface in alluxio.grpc
 
JobSource - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.job.JobSource
JobSource - Enum in alluxio.job.wire
The JobSource for a Cmd job.
JOBSOURCE_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
JobState - Enum in alluxio.scheduler.job
Job status.
JOBSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobStatusBlock
 
JobStatusBlock - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobStatusBlock
JobStatusBlock.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobStatusBlock
JOBSTATUSBLOCK_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdStatusBlock
 
JobStatusBlockOrBuilder - Interface in alluxio.grpc
 
JOBSTOPPED_FIELD_NUMBER - Static variable in class alluxio.grpc.StopJobPResponse
 
JobType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.job.JobType
JobUfsManager - Class in alluxio.underfs
Implementation of UfsManager to manage the ufs used by different job service processes.
JobUfsManager() - Constructor for class alluxio.underfs.JobUfsManager
Constructs an instance of JobUfsManager.
JobUnused - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobUnused
JobUnused.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobUnused
JobUnusedOrBuilder - Interface in alluxio.grpc
 
JobUtils - Class in alluxio.job.util
Utility class to make it easier to write jobs.
JobWorker - Class in alluxio.worker
A job worker that manages all the worker-related activities.
JobWorkerHealth - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobWorkerHealth
JobWorkerHealth - Class in alluxio.job.wire
The job worker health information.
JobWorkerHealth(long, List<Double>, int, int, int, String) - Constructor for class alluxio.job.wire.JobWorkerHealth
Default constructor.
JobWorkerHealth(long, List<Double>, int, int, int, String, BuildVersion) - Constructor for class alluxio.job.wire.JobWorkerHealth
Default constructor.
JobWorkerHealth(JobWorkerHealth) - Constructor for class alluxio.job.wire.JobWorkerHealth
Constructor from the grpc representation.
JobWorkerHealth.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.JobWorkerHealth
JOBWORKERHEALTH_FIELD_NUMBER - Static variable in class alluxio.grpc.JobHeartbeatPRequest
 
JobWorkerHealthCheckClient - Class in alluxio.worker.job
JobWorkerHealthCheckClient check if worker is serving RPC.
JobWorkerHealthCheckClient(InetSocketAddress, Supplier<RetryPolicy>, AlluxioConfiguration) - Constructor for class alluxio.worker.job.JobWorkerHealthCheckClient
Creates a worker health check client.
JobWorkerHealthOrBuilder - Interface in alluxio.grpc
 
JobWorkerHealthReport(HardwareAbstractionLayer, WorkerNetAddress) - Constructor for class alluxio.worker.job.command.JobWorkerHealthReporter.JobWorkerHealthReport
JobWorkerHealthReporter - Class in alluxio.worker.job.command
The job worker health reporter.
JobWorkerHealthReporter(WorkerNetAddress) - Constructor for class alluxio.worker.job.command.JobWorkerHealthReporter
Creates a new instance of JobWorkerHealthReporter.
JobWorkerHealthReporter.JobWorkerHealthReport - Class in alluxio.worker.job.command
It represents the job worker health information.
JobWorkerIdRegistry - Class in alluxio.worker
The single place to get, set, and update job worker id.
JobWorkerProcess - Interface in alluxio.worker
A job worker in the Alluxio system.
JobWorkerProcess.Factory - Class in alluxio.worker
Factory for creating JobWorkerProcess.
JobWorkerWebServer - Class in alluxio.web
Job master web server.
JobWorkerWebServer(String, InetSocketAddress, JobWorkerProcess) - Constructor for class alluxio.web.JobWorkerWebServer
Creates a new instance of JobWorkerWebServer.
join(String) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
join(AlluxioURI) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
join() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the result value when complete, or throws an (unchecked) exception if completed exceptionally.
join() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the result of the computation when it is done.
join(T, Map<WorkerInfo, SerializableVoid>) - Method in class alluxio.job.plan.AbstractVoidPlanDefinition
 
join(T, Map<WorkerInfo, R>) - Method in interface alluxio.job.plan.PlanDefinition
Joins the task results on the master.
join(StressBenchConfig, Map<WorkerInfo, String>) - Method in class alluxio.job.plan.stress.StressBenchDefinition
 
join(WorkerInfo) - Method in class alluxio.membership.EtcdMembershipManager
 
join(WorkerInfo) - Method in class alluxio.membership.MasterMembershipManager
 
join(WorkerInfo) - Method in interface alluxio.membership.MembershipManager
An idempotent call to register to join the membership.
join(WorkerInfo) - Method in class alluxio.membership.StaticMembershipManager
 
joinUnsafe(String) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
Journal - Class in alluxio.master.backcompat
Class representing a journal used by the backwards compatibility test.
journal(Journal.JournalEntry) - Method in class alluxio.master.file.RpcContext
Syntax sugar for getJournalContext().append(entry).
Journal - Interface in alluxio.master.journal
A journal for persisting journal entries.
Journal - Interface in alluxio.master.journalv0
The read-only journal.
Journal - Class in alluxio.proto.journal
 
Journal.Factory - Class in alluxio.master.journalv0
A Journal factory.
Journal.JournalEntry - Class in alluxio.proto.journal
next available id: 56
Journal.JournalEntry.Builder - Class in alluxio.proto.journal
next available id: 56
Journal.JournalEntryOrBuilder - Interface in alluxio.proto.journal
 
Journal.JournalOpPId - Class in alluxio.proto.journal
Unique operation id.
Journal.JournalOpPId.Builder - Class in alluxio.proto.journal
Unique operation id.
Journal.JournalOpPIdOrBuilder - Interface in alluxio.proto.journal
 
JOURNAL_ENTRIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
JOURNAL_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
JOURNAL_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
JOURNAL_MASTER_CLIENT_SERVICE = 13;
JOURNAL_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
JOURNAL_MASTER_NAME - Static variable in class alluxio.Constants
 
JOURNAL_MIGRATION - Static variable in class alluxio.multi.process.PortCoordination
 
JOURNAL_STOP_MULTI_MASTER - Static variable in class alluxio.multi.process.PortCoordination
 
JOURNAL_STOP_SINGLE_MASTER - Static variable in class alluxio.multi.process.PortCoordination
 
JournalCheckpointFormat - Class in alluxio.master.journal.checkpoint
Format for checkpoints written as sequential JournalEntry protocol buffers.
JournalCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.JournalCheckpointFormat
 
JournalCheckpointFormat.JournalCheckpointReader - Class in alluxio.master.journal.checkpoint
Reads journal entries from a checkpoint stream.
JournalCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.JournalCheckpointFormat.JournalCheckpointReader
 
JournalCheckpointStreamable - Interface in alluxio.master.journalv0
This interface enables streaming out to the journal checkpoint.
JournalClosedException - Exception in alluxio.exception
Exception thrown to indicate that an operation failed because the journal has been closed.
JournalClosedException(String) - Constructor for exception alluxio.exception.JournalClosedException
Constructs a JournalClosedException with the specified detail message.
JournalClosedException.IOJournalClosedException - Exception in alluxio.exception
Same as JournalClosedException, but extends IOException for situations where only IOException is allowed.
JournalCommand - Class in alluxio.cli.fsadmin.command
Command for seeing/managing quorum state of embedded journal.
JournalCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.JournalCommand
 
JournalContext - Interface in alluxio.master.journal
Context for storing journaling information.
JournalCopyJobFactory - Class in alluxio.master.job
Factory for creating LoadJobs from journal entries.
JournalCopyJobFactory(Job.CopyJobEntry, DefaultFileSystemMaster) - Constructor for class alluxio.master.job.JournalCopyJobFactory
Create factory.
JournalDiskInfo - Class in alluxio.wire
A class representing the state of a physical device.
JournalDiskInfo(String, String, long, long, long, String) - Constructor for class alluxio.wire.JournalDiskInfo
Create a new instance of JournalDiskInfo representing the current utilization for a particular block device.
JournalDomain - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.journal.JournalDomain
Journaled - Interface in alluxio.master.journal
Interface for classes with journaled state.
JournaledGroup - Class in alluxio.master.journal
Convenience class which groups together multiple Journaled components as a single Journaled component.
JournaledGroup(List<Journaled>, CheckpointName) - Constructor for class alluxio.master.journal.JournaledGroup
Creates an instance of a single journaled component, from a list of journaled components.
JournaledJobMetaStore - Class in alluxio.master.scheduler
A journaled job meta store.
JournaledJobMetaStore(DefaultFileSystemMaster) - Constructor for class alluxio.master.scheduler.JournaledJobMetaStore
Creates a new instance of JournaledJobMetaStore.
JOURNALENTRIESSINCECHECKPOINT_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterHeartbeatPOptions
 
JournalEntryAssociation - Class in alluxio.master.journal
Association from journal entry to the master it applies to.
JournalEntryIterable - Interface in alluxio.master.journal
Interface to get an iterator of Journal.JournalEntrys.
JournalEntryMerger - Interface in alluxio.master.journal
The interface for a journal entry merge which merges multiple inode journals on the same inode object into one.
JournalEntryRepresentable - Interface in alluxio.master.journal
This interface enables representing a class as a Journal.JournalEntry.
JournalEntryRepresentable - Interface in alluxio.master.journalv0
This interface enables representing a class as a Journal.JournalEntry.
JournalEntryStreamReader - Class in alluxio.master.journal
Class for reading journal entries from an input stream.
JournalEntryStreamReader(InputStream) - Constructor for class alluxio.master.journal.JournalEntryStreamReader
 
JournalFactory - Interface in alluxio.master.journalv0
Factory for creating named journals.
JournalFileParser - Interface in alluxio.master.journal
An interface to parse a journal file.
JournalFileParser.Factory - Class in alluxio.master.journal
Factory to create JournalFileParser.
JournalFormatter - Interface in alluxio.master.journalv0
This describes the interface for serializing and de-serializing entries in the journal.
JournalFormatter.Factory - Class in alluxio.master.journalv0
Factory for JournalFormatter.
JournalInputStream - Interface in alluxio.master.journalv0
This input stream retrieves Journal.JournalEntry from journal checkpoints and journal logs.
JournalLoadJobFactory - Class in alluxio.master.job
Factory for creating LoadJobs from journal entries.
JournalLoadJobFactory(Job.LoadJobEntry, FileSystemMaster) - Constructor for class alluxio.master.job.JournalLoadJobFactory
Create factory.
JournalMaster - Interface in alluxio.master.journal
Interface for journal master implementations.
JournalMasterClient - Interface in alluxio.client.journal
Interface for a journal master client.
JournalMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains journal master service endpoints for Alluxio clients.
JournalMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains journal master service endpoints for Alluxio clients.
JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service JournalMasterClientService.
JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service JournalMasterClientService.
JournalMasterClientServiceGrpc.JournalMasterClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service JournalMasterClientService.
JournalMasterClientServiceGrpc.JournalMasterClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service JournalMasterClientService.
JournalMasterClientServiceHandler - Class in alluxio.master.journal
This class is a gRPC handler for journal master RPCs invoked by an Alluxio client.
JournalMasterClientServiceHandler(JournalMaster) - Constructor for class alluxio.master.journal.JournalMasterClientServiceHandler
Creates gRPC service handler for JobMaster service.
JournalMasterClientServiceImplBase() - Constructor for class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceImplBase
 
JournalMasterFactory - Class in alluxio.master.journal
Factory to create a JournalMaster instance.
JournalMasterFactory() - Constructor for class alluxio.master.journal.JournalMasterFactory
 
JournalMasterProto - Class in alluxio.grpc
 
JournalMoveJobFactory - Class in alluxio.master.job
Factory for creating MoveJobs from journal entries.
JournalMoveJobFactory(Job.MoveJobEntry, DefaultFileSystemMaster) - Constructor for class alluxio.master.job.JournalMoveJobFactory
Create factory.
JournalOutputStream - Interface in alluxio.master.journalv0
This output stream writes Journal.JournalEntry objects to the journal.
JournalQueryRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.JournalQueryRequest
JournalQueryRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.JournalQueryRequest
JournalQueryRequestOrBuilder - Interface in alluxio.grpc
 
JournalQueryResponse - Class in alluxio.grpc
Deprecated.
JournalQueryResponse.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.JournalQueryResponse
JournalQueryResponseOrBuilder - Interface in alluxio.grpc
Deprecated.
JournalReader - Interface in alluxio.master.journal
This class manages reading from the journal.
JournalReader - Interface in alluxio.master.journalv0
This class manages reading from the journal.
JournalReader.State - Enum in alluxio.master.journal
States that the reader can be after calling JournalReader.advance().
JournalReaderOptions - Class in alluxio.master.journal.options
Options to create a journal reader.
JournalSink - Interface in alluxio.master.journal.sink
The interface for the journal to push events.
JournalSpaceMonitor - Class in alluxio.master.meta
A heartbeat executor which periodically tracks the amount of disk space available for a particular path, generally the disk holding the journal.
JournalSpaceMonitor(AlluxioConfiguration) - Constructor for class alluxio.master.meta.JournalSpaceMonitor
Convenience method for JournalSpaceMonitor(String, long).
JournalSpaceMonitor(String, long) - Constructor for class alluxio.master.meta.JournalSpaceMonitor
 
JournalStateMachine - Class in alluxio.master.journal.raft
A state machine for managing all of Alluxio's journaled state.
JournalStateMachine(Map<String, RaftJournal>, RaftJournalSystem, SnapshotDirStateMachineStorage) - Constructor for class alluxio.master.journal.raft.JournalStateMachine
 
JournalSystem - Interface in alluxio.master.journal
A journal system for storing and applying journal entries.
JournalSystem.Builder - Class in alluxio.master.journal
Builder for constructing a journal system.
JournalSystem.Mode - Enum in alluxio.master.journal
The mode of the journal system.
JournalTool - Class in alluxio.master.journal.tool
Tool for converting journal to a human-readable format.
JournalTool - Class in alluxio.master.journalv0
Tool for reading the journal.
JournalType - Enum in alluxio.master.journal
Enumerates the different types of journals that Alluxio may be configured with.
JournalUtils - Class in alluxio.master.journal
Utility methods for working with the Alluxio journal.
JournalWriter - Interface in alluxio.master.journal
Interface for a class that can write and flush journal entries.
JournalWriter - Interface in alluxio.master.journalv0
This class manages all the writes to the journal.
JournalWriterOptions - Class in alluxio.master.journal.options
Options to create a JournalWriter.
JSON_VALUE - Static variable in enum alluxio.grpc.JobProgressReportFormat
JSON = 2;
JsonSerializable - Interface in alluxio.util
This represents stress test objects that can be ser/de to/from json.
jumpAndExecute(long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
Jumps to a future time by a given duration.
JVM_MONITOR_INFO_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
JVM_MONITOR_INFO_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JVM_MONITOR_SLEEP_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
JVM_MONITOR_SLEEP_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JVM_MONITOR_WARN_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
JVM_MONITOR_WARN_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JvmMonitorService - Class in alluxio.master.service.jvmmonitor
JvmMonitorService.Factory - Class in alluxio.master.service.jvmmonitor
Factory that returns the appropriate JvmMonitorService based on configuration.
JvmPauseMonitor - Class in alluxio.util
Class to monitor JVM with a daemon thread, the thread sleep period of time and get the true time the sleep takes.
JvmPauseMonitor(long, long, long) - Constructor for class alluxio.util.JvmPauseMonitor
Constructs JvmPauseMonitor.
JvmPauseMonitor.GarbageCollectorMXBeanView - Class in alluxio.util
An unmodifiable view of a garbage collector MX Bean.
JvmSource - Class in alluxio.metrics.source
A Source which collects JVM metrics, including JVM memory usage, GC counts, GC times, etc.
JvmSource() - Constructor for class alluxio.metrics.source.JvmSource
Creates a new JvmSource and register all JVM metrics.
JvmSpaceReviewer - Class in alluxio.master.block
This reviews the heap allocation status to decide whether a request should be accepted.

K

KB - Static variable in class alluxio.Constants
 
keepAliveTime(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the server keep-alive time.
keepAliveTimeout(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the server keep-alive timeout.
Key(Subject, AlluxioConfiguration) - Constructor for class alluxio.client.file.FileSystemCache.Key
 
Key(AlluxioURI, Map<String, Object>) - Constructor for class alluxio.underfs.AbstractUfsManager.Key
 
KEY_FIELD_NUMBER - Static variable in class alluxio.grpc.LocationBlockIdListEntry
 
KEY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.StringPairEntry
 
KEYS_FIELD_NUMBER - Static variable in class alluxio.grpc.RemovePathConfigurationPRequest
 
keySet() - Method in class alluxio.collections.ConcurrentIdentityHashMap
Returns a set representing all keys contained within the map.
keySet() - Method in interface alluxio.conf.AlluxioConfiguration
 
keySet() - Method in class alluxio.conf.AlluxioProperties
 
keySet() - Static method in class alluxio.conf.Configuration
 
keySet() - Method in class alluxio.conf.InstancedConfiguration
 
keySet() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
kickStartTasks() - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoHub
Kick stark tasks for each worker task q.
killWorkerProcesses() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Kills all worker processes without forgetting them in the master, so we can validate the master mechanism handling dead workers.
KRB5_CONF_FILE - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
KRB_KEYTAB_LOGIN_AUTO_RENEW - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 

L

LAST_ACCESS_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
LAST_ACCESS_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
LAST_ACCESS_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
LAST_ACCESSED_MS_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
LAST_CONTACT_SEC_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
LAST_CONTACT_SEC = 5;
LAST_MODIFICATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
LAST_MODIFICATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
LAST_MODIFICATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
LAST_MODIFICATION_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
LAST_MODIFIED_MS_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
LAST_MODIFIED_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
LAST_TIER - Static variable in class alluxio.Constants
 
LASTACCESSTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
LASTCHECKPOINTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterHeartbeatPOptions
 
LASTCONTACTSEC_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
LastContactSecComparator() - Constructor for class alluxio.wire.WorkerInfo.LastContactSecComparator
LastContactSecComparator constructor.
LASTHEARTBEATTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyStatus
 
lastIndexOf(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
LASTMODIFICATIONTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
LastModifiedDateFactory() - Constructor for class alluxio.master.predicate.DatePredicate.LastModifiedDateFactory
 
LASTUPDATED_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
LASTUPDATED_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
LASTUPDATEDTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.ActionInfo
 
LASTUPDATEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
 
LATEST_FIELD_NUMBER - Static variable in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
LatestSnapshotInfoPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.LatestSnapshotInfoPRequest
LatestSnapshotInfoPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.LatestSnapshotInfoPRequest
LatestSnapshotInfoPRequestOrBuilder - Interface in alluxio.grpc
 
launchFuse(AlluxioJniFuseFileSystem, FileSystemContext, FuseOptions, boolean) - Static method in class alluxio.fuse.AlluxioFuse
Launches Fuse application.
LaunchUserGroupAuthPolicy - Class in alluxio.fuse.auth
An authentication policy that follows the default security implementation that the user group is set to the user that launches the Fuse application.
LaunchUserGroupAuthPolicy(FileSystem, Optional<FuseFileSystem>) - Constructor for class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
Layout - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Layout
Layout.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Layout
LAYOUT_DATA_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Layout
 
LAYOUT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
LAYOUT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Transformation
 
LAYOUT_SPEC_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Layout
 
LAYOUT_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Layout
 
LayoutOrBuilder - Interface in alluxio.grpc.table
 
LayoutSpec - Class in alluxio.grpc.table
TODO(gpang): update
LayoutSpec.Builder - Class in alluxio.grpc.table
TODO(gpang): update
LayoutSpecOrBuilder - Interface in alluxio.grpc.table
 
LazyUfsBlockLocationCache - Class in alluxio.master.file.meta
Lazily cache the block locations only when needed.
LazyUfsBlockLocationCache(MountTable) - Constructor for class alluxio.master.file.meta.LazyUfsBlockLocationCache
Creates a new instance of UfsBlockLocationCache.
LEADER_MASTER_ADDRESS_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
LEADER_MASTER_ADDRESS = 0;
LEADERMASTERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
LEAF_NODE_VALUE - Static variable in enum alluxio.grpc.XAttrPropagationStrategy
LEAF_NODE = 2;
LEAK_DETECTOR_EXIT_ON_LEAK - Static variable in class alluxio.conf.PropertyKey
 
LEAK_DETECTOR_EXIT_ON_LEAK - Static variable in class alluxio.conf.PropertyKey.Name
 
LEAK_DETECTOR_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
LEAK_DETECTOR_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
Lease(long, long) - Constructor for class alluxio.membership.AlluxioEtcdClient.Lease
CTOR for Lease.
LEASTSIGNIFICANTBITS_FIELD_NUMBER - Static variable in class alluxio.grpc.FsOpPId
 
LEASTSIGNIFICANTBITS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalOpPId
 
length() - Method in class alluxio.conf.PropertyKey
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.Block
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockInfo
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.File
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.Route
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.BlockInfoEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.meta.Block.BlockMeta
 
LENGTH_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
level() - Method in class alluxio.client.quota.CacheScope
 
LFUCacheEvictor - Class in alluxio.client.file.cache.evictor
LFU client-side cache eviction policy.
LFUCacheEvictor(CacheEvictorOptions) - Constructor for class alluxio.client.file.cache.evictor.LFUCacheEvictor
Required constructor.
LibFuse - Class in alluxio.jnifuse
 
LibFuse() - Constructor for class alluxio.jnifuse.LibFuse
 
LibfuseVersion - Enum in alluxio.jnifuse.utils
The libfuse version set by the user.
LimitedLifeMasterProcess - Class in alluxio.multi.process
Wrapper around AlluxioMaster which will exit after a limited amount of time.
LimitedLifeMasterProcess() - Constructor for class alluxio.multi.process.LimitedLifeMasterProcess
 
LimitedLifeWorkerProcess - Class in alluxio.multi.process
Wrapper around AlluxioWorker which will exit after a limited amount of time.
LimitedLifeWorkerProcess() - Constructor for class alluxio.multi.process.LimitedLifeWorkerProcess
 
limitLife(long) - Static method in class alluxio.multi.process.Utils
Launches a thread to terminate the current process after the specified period has elapsed.
LineGraph - Class in alluxio.stress.graph
A line graph representation.
LineGraph(String, List<String>, String, String) - Constructor for class alluxio.stress.graph.LineGraph
Creates an instance.
LineGraph.Data - Class in alluxio.stress.graph
This represents the data for a line graph.
link(String, String) - Method in interface alluxio.jnifuse.FuseFileSystem
 
list() - Method in interface alluxio.client.job.JobMasterClient
 
list(ListAllPOptions) - Method in interface alluxio.client.job.JobMasterClient
 
list(ListAllPOptions) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
LIST - Static variable in class alluxio.job.ServiceConstants
 
list(ListAllPOptions) - Method in class alluxio.master.job.JobMaster
 
list(List<String>, String) - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
Lists all the jobs in the history.
list() - Method in class alluxio.master.job.plan.PlanTracker
A collection of all job Ids currently tracked in the job master.
list() - Method in class alluxio.master.job.workflow.WorkflowTracker
 
LIST_STATUS - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
listAll(ListAllPRequest, StreamObserver<ListAllPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Lists ids of all known jobs.
listAll(ListAllPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Lists ids of all known jobs.
listAll(ListAllPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Lists ids of all known jobs.
listAll(ListAllPRequest, StreamObserver<ListAllPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Lists ids of all known jobs.
listAll(ListAllPRequest, StreamObserver<ListAllPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
listAllMyBuckets() - Method in class alluxio.proxy.s3.S3RestServiceHandler
Lists all buckets owned by you.
ListAllMyBucketsResult - Class in alluxio.s3
Implementation of ListAllMyBucketsResult according to https://docs.aws.amazon.com/AmazonS3/latest/API/API_ListBuckets.html.
ListAllMyBucketsResult() - Constructor for class alluxio.s3.ListAllMyBucketsResult
Creates a ListAllMyBucketsResult for deserialization only.
ListAllMyBucketsResult(List<URIStatus>) - Constructor for class alluxio.s3.ListAllMyBucketsResult
ListAllMyBucketsResult.Bucket - Class in alluxio.s3
The Bucket object.
ListAllPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.ListAllPOptions
ListAllPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.ListAllPOptions
ListAllPOptionsOrBuilder - Interface in alluxio.grpc
 
ListAllPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.ListAllPRequest
ListAllPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.ListAllPRequest
ListAllPRequestOrBuilder - Interface in alluxio.grpc
 
ListAllPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.ListAllPResponse
ListAllPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.ListAllPResponse
ListAllPResponseOrBuilder - Interface in alluxio.grpc
 
ListBucketOptions - Class in alluxio.s3
The options for list bucket operation.
ListBucketResult - Class in alluxio.s3
Get bucket result defined in https://docs.aws.amazon.com/AmazonS3/latest/API/API_ListObjects.html It will be encoded into an XML string to be returned as a response for the REST call.
ListBucketResult() - Constructor for class alluxio.s3.ListBucketResult
Creates an ListBucketResult.
ListBucketResult(String, List<URIStatus>, ListBucketOptions) - Constructor for class alluxio.s3.ListBucketResult
Creates an ListBucketResult.
ListBucketResult.CommonPrefix - Class in alluxio.s3
Common Prefixes list placeholder object.
ListBucketResult.Content - Class in alluxio.s3
Object metadata class.
listBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
listCached(String, boolean) - Method in class alluxio.worker.dora.DoraMetaManager
Get the cached listing result from the listing cache.
listCmds(ListAllPOptions) - Method in class alluxio.master.job.JobMaster
 
listDetailed() - Method in interface alluxio.client.job.JobMasterClient
 
listDetailed() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
listDetailed() - Method in class alluxio.master.job.JobMaster
 
listedItem() - Method in class alluxio.master.file.contexts.ListStatusContext
Called each time an item is listed.
listen(InetSocketAddress, Consumer<GrpcMessagingConnection>) - Method in class alluxio.master.transport.GrpcMessagingServer
Listens to the given address.
Listener<T> - Interface in alluxio.master.transport
Context for unregistering a registered listener.
Listeners<T> - Class in alluxio.master.transport
A class to hold all listeners belong to given type T.
Listeners() - Constructor for class alluxio.master.transport.Listeners
Empty constructor to construct Listeners.
Listeners.ListenerHolder - Class in alluxio.master.transport
The listener holder with messaging context.
listExtensions(String) - Static method in class alluxio.util.ExtensionUtils
List extension jars from the configured extensions directory.
listFromUfs(String, boolean) - Method in class alluxio.worker.dora.DoraMetaManager
Lists a directory from UFS.
listFromUfsThenCache(String, boolean) - Method in class alluxio.worker.dora.DoraMetaManager
Lists a directory from UFS and cache it into the listing cache if it exists.
listInternal(String, ListOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
Lists the files in the given path, the paths will be their logical names and not contain the folder suffix.
listIterator() - Method in class alluxio.collections.UnmodifiableArrayList
 
listIterator(int) - Method in class alluxio.collections.UnmodifiableArrayList
 
listLargeDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing large directory.
ListMultipartUploadsResult - Class in alluxio.proxy.s3
Implementation of ListMultipartUploadsResult according to https://docs.aws.amazon.com/AmazonS3/latest/API/API_ListMultipartUploads.html.
ListMultipartUploadsResult() - Constructor for class alluxio.proxy.s3.ListMultipartUploadsResult
ListMultipartUploadsResult.Upload - Class in alluxio.proxy.s3
The Upload POJO.
ListOptions - Class in alluxio.underfs.options
Method options for listing a directory in UnderFileSystem.
ListPartsResult - Class in alluxio.proxy.s3
Result returned after requests for listing parts of a multipart upload.
ListPartsResult() - Constructor for class alluxio.proxy.s3.ListPartsResult
Constructs a default ListPartsResult.
ListPartsResult.Part - Class in alluxio.proxy.s3
Part contains metadata of a part of the object in multipart upload.
listPolicy(ListPolicyPRequest, StreamObserver<ListPolicyPResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
Returns the list of policies
listPolicy(ListPolicyPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
Returns the list of policies
listPolicy(ListPolicyPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
Returns the list of policies
listPolicy(ListPolicyPRequest, StreamObserver<ListPolicyPResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
Returns the list of policies
ListPolicyPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.ListPolicyPOptions
ListPolicyPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.ListPolicyPOptions
ListPolicyPOptionsOrBuilder - Interface in alluxio.grpc
 
ListPolicyPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.ListPolicyPRequest
ListPolicyPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.ListPolicyPRequest
ListPolicyPRequestOrBuilder - Interface in alluxio.grpc
 
ListPolicyPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.ListPolicyPResponse
ListPolicyPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.ListPolicyPResponse
ListPolicyPResponseOrBuilder - Interface in alluxio.grpc
 
listProxyStatus() - Method in interface alluxio.client.meta.MetaMasterClient
Lists information of all known proxy instances from the primary master.
listProxyStatus() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
listProxyStatus(ListProxyStatusPRequest, StreamObserver<ListProxyStatusPResponse>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
Returns the status of all known Proxy instances in the cluster.
listProxyStatus(ListProxyStatusPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
Returns the status of all known Proxy instances in the cluster.
listProxyStatus(ListProxyStatusPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
Returns the status of all known Proxy instances in the cluster.
listProxyStatus(ListProxyStatusPRequest, StreamObserver<ListProxyStatusPResponse>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
Returns the status of all known Proxy instances in the cluster.
listProxyStatus() - Method in class alluxio.master.meta.DefaultMetaMaster
 
listProxyStatus() - Method in interface alluxio.master.meta.MetaMaster
Lists information of all known Proxy instances.
listProxyStatus(ListProxyStatusPRequest, StreamObserver<ListProxyStatusPResponse>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
ListProxyStatusPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ListProxyStatusPOptions
ListProxyStatusPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ListProxyStatusPOptions
ListProxyStatusPOptionsOrBuilder - Interface in alluxio.grpc
 
ListProxyStatusPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ListProxyStatusPRequest
ListProxyStatusPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ListProxyStatusPRequest
ListProxyStatusPRequestOrBuilder - Interface in alluxio.grpc
 
ListProxyStatusPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ListProxyStatusPResponse
ListProxyStatusPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ListProxyStatusPResponse
ListProxyStatusPResponseOrBuilder - Interface in alluxio.grpc
 
listStatus(ListStatusPRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
List status from Worker.
listStatus(ListStatusPRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
listStatus(String, ListStatusPOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
List Status from Worker.
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
listStatus(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.listStatus(AlluxioURI, ListStatusPOptions) with default options.
listStatus(AlluxioURI, ListStatusPOptions) - Method in interface alluxio.client.file.FileSystem
If the path is a directory, returns the URIStatus of all the direct entries in it.
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
listStatus(AlluxioURI, ListStatusPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
 
listStatus(AlluxioURI) - Method in class alluxio.client.file.MetadataCache
 
listStatus(String) - Method in class alluxio.client.file.MetadataCache
 
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
listStatus(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
listStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
listStatus(String, ListOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
listStatus(ListStatusPRequest, StreamObserver<ListStatusPResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
If the path points to a file, the method returns a singleton with its file information.
listStatus(ListStatusPRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
If the path points to a file, the method returns a singleton with its file information.
listStatus(ListStatusPRequest, StreamObserver<ListStatusPResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
If the path points to a file, the method returns a singleton with its file information.
listStatus(ListStatusPRequest, StreamObserver<ListStatusPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
If the path points to a file, the method returns a singleton with its file information.
listStatus(ListStatusPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
If the path points to a file, the method returns a singleton with its file information.
listStatus(ListStatusPRequest, StreamObserver<ListStatusPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
If the path points to a file, the method returns a singleton with its file information.
listStatus(Path) - Method in class alluxio.hadoop.AbstractFileSystem
 
listStatus(Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
listStatus(AlluxioURI, ListStatusContext, ResultStream<FileInfo>) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
listStatus(AlluxioURI, ListStatusContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
listStatus(AlluxioURI, ListStatusContext) - Method in interface alluxio.master.file.FileSystemMaster
Returns a list of FileInfo for a given path.
listStatus(AlluxioURI, ListStatusContext, ResultStream<FileInfo>) - Method in interface alluxio.master.file.FileSystemMaster
Enumerates given path to given batch tracker.
listStatus(ListStatusPRequest, StreamObserver<ListStatusPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
listStatus(String, ListStatusPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.BaseUnderFileSystem
 
listStatus(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
Each string is a name rather than a complete path.
listStatus(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
listStatus(String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
listStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
listStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname.
listStatus(String, ListOptions) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname, with options.
listStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
listStatus(String, ListStatusPOptions) - Method in interface alluxio.worker.dora.DoraWorker
List status from Under File System.
listStatus(String, ListStatusPOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
listStatus(ListStatusPRequest, StreamObserver<ListStatusPResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
ListStatusContext - Class in alluxio.master.file.contexts
Used to merge and wrap ListStatusPOptions.
listStatusDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
listStatusEmptyTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing empty directory.
listStatuses(String, ListOptions) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname, with options.
listStatusFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing status on file.
listStatusIterable(String, ListOptions, String, int) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
listStatusIterable(String, ListOptions, String, int) - Method in class alluxio.underfs.BaseUnderFileSystem
 
listStatusIterable(String, ListOptions, String, int) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
listStatusIterable(String, ListOptions, String, int) - Method in interface alluxio.underfs.UnderFileSystem
Lists the ufs statuses iteratively.
listStatusIterable(String, ListOptions, String, int) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
listStatusPartial(AlluxioURI, ListStatusPartialPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
listStatusPartial(AlluxioURI, ListStatusPartialPOptions) - Method in interface alluxio.client.file.FileSystem
Same as FileSystem.listStatus(AlluxioURI, ListStatusPOptions) except may only return a subset of the results as determined by the options parameter.
listStatusPartial(AlluxioURI, ListStatusPartialPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
 
listStatusPartial(AlluxioURI, ListStatusPartialPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
listStatusPartial(AlluxioURI, ListStatusPartialPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
listStatusPartial(ListStatusPartialPRequest, StreamObserver<ListStatusPartialPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
If the path points to a file, the method returns a singleton with its file information.
listStatusPartial(ListStatusPartialPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
If the path points to a file, the method returns a singleton with its file information.
listStatusPartial(ListStatusPartialPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
If the path points to a file, the method returns a singleton with its file information.
listStatusPartial(ListStatusPartialPRequest, StreamObserver<ListStatusPartialPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
If the path points to a file, the method returns a singleton with its file information.
listStatusPartial(ListStatusPartialPRequest, StreamObserver<ListStatusPartialPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
listStatusPartialDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
ListStatusPartialPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPartialPOptions
ListStatusPartialPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPartialPOptions
ListStatusPartialPOptions.OffsetTypeCase - Enum in alluxio.grpc
 
ListStatusPartialPOptionsOrBuilder - Interface in alluxio.grpc
 
ListStatusPartialPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPartialPRequest
ListStatusPartialPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPartialPRequest
ListStatusPartialPRequestOrBuilder - Interface in alluxio.grpc
 
ListStatusPartialPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPartialPResponse
ListStatusPartialPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPartialPResponse
ListStatusPartialPResponseOrBuilder - Interface in alluxio.grpc
 
ListStatusPartialResult - Class in alluxio.client.file
Contains information about the result of a partial listing.
ListStatusPartialResult(List<URIStatus>, boolean, long) - Constructor for class alluxio.client.file.ListStatusPartialResult
Constructor.
ListStatusPartialResultStream - Class in alluxio.master.file
Used to track the results of a call to a partial listing.
ListStatusPartialResultStream(StreamObserver<ListStatusPartialPResponse>, ListStatusContext) - Constructor for class alluxio.master.file.ListStatusPartialResultStream
Create a result stream for a partial listing.
ListStatusPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPOptions
ListStatusPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPOptions
ListStatusPOptionsOrBuilder - Interface in alluxio.grpc
 
ListStatusPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPRequest
ListStatusPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPRequest
ListStatusPRequestOrBuilder - Interface in alluxio.grpc
 
ListStatusPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPResponse
ListStatusPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ListStatusPResponse
ListStatusPResponseOrBuilder - Interface in alluxio.grpc
 
listStatusRecursiveTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing status recursively.
ListStatusResult - Class in alluxio.worker.dora
The list status results stored in the cache.
ListStatusResultStream - Class in alluxio.master.file
Used to define a single batch of listing.
ListStatusResultStream(int, StreamObserver<ListStatusPResponse>) - Constructor for class alluxio.master.file.ListStatusResultStream
Creates a new result streamer for listStatus call.
listStatusS3RootTest() - Method in class alluxio.cli.S3ASpecificOperations
Test for listing status of the root directory of the UFS.
listStatusTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing status.
listToString(List<T>) - Static method in class alluxio.util.CommonUtils
Converts a list of objects to a string.
listxattrCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
LIVE_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
LIVE_VALUE - Static variable in enum alluxio.grpc.WorkerRange
LIVE = 2;
LIVE_WORKER_NUM_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
LIVE_WORKER_NUM = 4;
LIVEWORKERNUM_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
load(LoadRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
load blocks into alluxio.
load(LoadRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
load(LoadRequest, StreamObserver<LoadResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
load(LoadRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
load(LoadRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
load(LoadRequest, StreamObserver<LoadResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
load(K) - Method in class alluxio.master.metastore.caching.Cache
Loads a key from the backing store.
load(List<Block>, UfsReadOptions) - Method in interface alluxio.worker.block.BlockStore
Load blocks into alluxio.
load(List<Block>, UfsReadOptions) - Method in interface alluxio.worker.block.BlockWorker
Load blocks into alluxio.
load(boolean, boolean, List<UfsStatus>, UfsReadOptions) - Method in interface alluxio.worker.dora.DoraWorker
Loads the metadata and data of files from UFS to Alluxio.
load(boolean, boolean, List<UfsStatus>, UfsReadOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
LOAD_JOB_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
LOAD_METADATA_ONLY_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileRequest
 
LOAD_METADATA_ONLY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
LOAD_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
LOAD_SESSION_ID - Static variable in class alluxio.Sessions
 
LOADAVERAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
loadClass(String, boolean) - Method in class alluxio.extensions.ExtensionsClassLoader
 
loadClusterDefaults(InetSocketAddress, Scope) - Static method in class alluxio.conf.Configuration
Loads cluster default values for workers from the meta master if it's not loaded yet.
LoadCommand - Class in alluxio.cli.fs.command
Loads a file or directory in Alluxio space, making it resident in Alluxio.
LoadCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.LoadCommand
Constructs a new instance to load a file or directory in Alluxio space.
loadCommands() - Method in class alluxio.cli.AbstractShell
Map structure: Command name => Command instance.
loadCommands() - Method in class alluxio.cli.bundler.CollectInfo
 
loadCommands(String, Class[], Object[]) - Static method in class alluxio.cli.CommandUtils
Get instances of all subclasses of Command in a sub-package called "command" the given package.
loadCommands() - Method in class alluxio.cli.extensions.ExtensionsShell
 
loadCommands() - Method in class alluxio.cli.fs.FileSystemShell
 
loadCommands(FileSystemContext) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Gets all Command instances in the same package as FileSystemShell and load them into a map.
loadCommands() - Method in class alluxio.cli.fsadmin.FileSystemAdminShell
 
loadConf(InetSocketAddress) - Method in class alluxio.ClientContext
This method will load the cluster and path level configuration defaults and update the configuration in one RPC.
loadConfIfNotLoaded(InetSocketAddress) - Method in class alluxio.ClientContext
Loads configuration if not loaded from meta master yet.
loadConfiguration(InetSocketAddress, AlluxioConfiguration, boolean, boolean) - Static method in class alluxio.conf.Configuration
Loads configuration from meta master in one RPC.
loadData(String, long, long) - Method in class alluxio.worker.dora.PagedDoraWorker
 
LoadDescendantPType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.fscommon.LoadDescendantPType
LOADDESCENDANTTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
 
LOADDIRECTCHILDREN_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
 
loadFile(LoadFileRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
load files.
loadFile(LoadFileRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
loadFile(LoadFileRequest, StreamObserver<LoadFileResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
loadFile(LoadFileRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
loadFile(LoadFileRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
loadFile(LoadFileRequest, StreamObserver<LoadFileResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
loadFile(LoadFileRequest, StreamObserver<LoadFileResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
LoadFileFailure - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadFileFailure
LoadFileFailure.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadFileFailure
LoadFileFailureOrBuilder - Interface in alluxio.grpc
 
LoadFileRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadFileRequest
LoadFileRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadFileRequest
LoadFileRequestOrBuilder - Interface in alluxio.grpc
 
LoadFileResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadFileResponse
LoadFileResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadFileResponse
LoadFileResponseOrBuilder - Interface in alluxio.grpc
 
loadFromUfs(String) - Method in class alluxio.worker.dora.DoraMetaManager
Gets file meta from UFS and loads it into metastore if exists.
loadHdfsConfig() - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
 
loadInode(long) - Method in class alluxio.master.file.meta.TtlBucketList
Load inode from inode store on processing the provided inode id.
LoadJob - Class in alluxio.master.job
Load job that loads a file or a directory into Alluxio.
LoadJob(String, String, OptionalLong, FileIterable) - Constructor for class alluxio.master.job.LoadJob
Constructor.
LoadJob(String, Optional<String>, String, OptionalLong, boolean, boolean, Iterable<FileInfo>) - Constructor for class alluxio.master.job.LoadJob
Constructor.
LoadJob.LoadTask - Class in alluxio.master.job
Loads blocks in a UFS through an Alluxio worker.
LoadJobFactory - Class in alluxio.master.job
Factory for creating LoadJobs that get file infos from master.
LoadJobFactory(LoadJobRequest) - Constructor for class alluxio.master.job.LoadJobFactory
Create factory.
LoadJobPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.LoadJobPOptions
LoadJobPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.LoadJobPOptions
LoadJobPOptionsOrBuilder - Interface in alluxio.grpc
 
LoadJobRequest - Class in alluxio.job
The request of loading files.
LoadJobRequest(String, LoadJobPOptions) - Constructor for class alluxio.job.LoadJobRequest
 
loadLatestSnapshot() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
Loads the latest snapshot information into the StateMachineStorage.
loadLibrary(LibfuseVersion) - Static method in class alluxio.jnifuse.LibFuse
 
loadLibrary(LibfuseVersion, String) - Method in class alluxio.jnifuse.utils.NativeLibraryLoader
Load the library.
loadMetadata(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
loadMetadata(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.loadMetadata(AlluxioURI, ListStatusPOptions) with default options.
loadMetadata(AlluxioURI, ListStatusPOptions) - Method in interface alluxio.client.file.FileSystem
Loads metadata about a path in the UFS to Alluxio.
loadMetadata(AlluxioURI, ListStatusPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
LoadMetadataContext - Class in alluxio.master.file.contexts
Used to merge and wrap LoadMetadataPOptions.
loadMetadataDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
loadMetadataIfNotExist(RpcContext, AlluxioURI, LoadMetadataContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
Loads metadata for the path if it is (non-existing || load direct children is set).
LOADMETADATAONLY_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
 
LOADMETADATAONLY_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadJobPOptions
 
LoadMetadataPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.LoadMetadataPOptions
LoadMetadataPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.LoadMetadataPOptions
LoadMetadataPOptionsOrBuilder - Interface in alluxio.grpc
 
LoadMetadataPType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.LoadMetadataPType
LoadMetadataType - Enum in alluxio.wire
Types for loading metadata.
LOADMETADATATYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.ExistsPOptions
 
LOADMETADATATYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPOptions
 
LOADMETADATATYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
 
LoadRequest - Class in alluxio.grpc
Request for load a block into alluxio next available id: 3
LoadRequest.Builder - Class in alluxio.grpc
Request for load a block into alluxio next available id: 3
LoadRequestOrBuilder - Interface in alluxio.grpc
 
LoadResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadResponse
LoadResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LoadResponse
LoadResponseOrBuilder - Interface in alluxio.grpc
 
LoadTask(List<Block>) - Constructor for class alluxio.master.job.LoadJob.LoadTask
Creates a new instance of LoadJob.LoadTask.
LOADTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
 
LocalAlluxioCluster - Class in alluxio.master
Local Alluxio cluster for integration tests.
LocalAlluxioCluster() - Constructor for class alluxio.master.LocalAlluxioCluster
Runs a test Alluxio cluster with a single Alluxio worker.
LocalAlluxioCluster(int, boolean) - Constructor for class alluxio.master.LocalAlluxioCluster
 
LocalAlluxioJobCluster - Class in alluxio.master
Local Alluxio job cluster.
LocalAlluxioJobCluster() - Constructor for class alluxio.master.LocalAlluxioJobCluster
Creates a new instance of LocalAlluxioJobCluster.
LocalAlluxioMaster - Class in alluxio.master
Constructs an isolated master.
LocalCacheFileInStream - Class in alluxio.client.file.cache
Implementation of FileInStream that reads from a local cache if possible.
LocalCacheFileInStream(URIStatus, LocalCacheFileInStream.FileInStreamOpener, CacheManager, AlluxioConfiguration, Optional<FileInStream>) - Constructor for class alluxio.client.file.cache.LocalCacheFileInStream
Constructor when the URIStatus is already available.
LocalCacheFileInStream.FileInStreamOpener - Interface in alluxio.client.file.cache
Interface to wrap open method of file system.
LocalCacheFileSystem - Class in alluxio.client.file.cache
A FileSystem implementation with a local cache.
LocalCacheFileSystem(CacheManager, FileSystem, AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.LocalCacheFileSystem
 
LocalCacheFileSystem - Class in alluxio.hadoop
An Alluxio client compatible with Apache Hadoop FileSystem interface, using Alluxio local cache.
LocalCacheFileSystem(FileSystem) - Constructor for class alluxio.hadoop.LocalCacheFileSystem
 
LocalCacheFileSystem(FileSystem, HadoopFileOpener) - Constructor for class alluxio.hadoop.LocalCacheFileSystem
 
LocalCacheManager - Class in alluxio.client.file.cache
A class to manage & serve cached pages.
LocalCachePositionReader - Class in alluxio.client.file.cache
Implementation of PositionReader that reads from a local cache if possible.
LocalFileInfo(String, String, long, long, long, boolean) - Constructor for class alluxio.util.webui.UIFileInfo.LocalFileInfo
Creates a new instance of UIFileInfo.LocalFileInfo.
LOCALFILESYSTEM_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPOptions
 
LocalPageStore - Class in alluxio.client.file.cache.store
The LocalPageStore is an implementation of PageStore which stores all pages in a directory somewhere on the local disk.
LocalPageStore(PageStoreOptions) - Constructor for class alluxio.client.file.cache.store.LocalPageStore
Creates a new instance of LocalPageStore.
LocalPageStoreDir - Class in alluxio.client.file.cache.store
 
LocalPageStoreDir(PageStoreOptions, PageStore, CacheEvictor) - Constructor for class alluxio.client.file.cache.store.LocalPageStoreDir
Constructor for LocalCacheDir.
LocalPositionReader - Class in alluxio.underfs.local
Implementation of PositionReader that reads from local UFS.
LocalPositionReader(String, long) - Constructor for class alluxio.underfs.local.LocalPositionReader
 
LocalUnderFileSystem - Class in alluxio.underfs.local
Local FS UnderFileSystem implementation.
LocalUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.local.LocalUnderFileSystem
Constructs a new LocalUnderFileSystem.
LocalUnderFileSystemFactory - Class in alluxio.underfs.local
Factory for creating LocalUnderFileSystem.
LocalUnderFileSystemFactory() - Constructor for class alluxio.underfs.local.LocalUnderFileSystemFactory
Constructs a new LocalUnderFileSystemFactory.
LocalWorkerPolicy - Class in alluxio.client.file.dora
A policy where a client will ONLY talk to a local worker.
LocalWorkerPolicy(AlluxioConfiguration) - Constructor for class alluxio.client.file.dora.LocalWorkerPolicy
Constructs a new LocalWorkerPolicy.
LOCATION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
LOCATION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
LocationBlockIdListEntry - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LocationBlockIdListEntry
LocationBlockIdListEntry.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.LocationBlockIdListEntry
LocationBlockIdListEntryOrBuilder - Interface in alluxio.grpc
 
LocationCommand - Class in alluxio.cli.fs.command
Displays a list of hosts that have the file specified in args stored.
LocationCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.LocationCommand
Constructs a new instance to display a list of hosts that have the file specified in args stored.
LOCATIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockInfo
 
lock() - Method in class alluxio.master.block.meta.WorkerMetaLock
 
lockBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Locks an existing block and guards subsequent reads on this block.
lockBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Obtains a read lock the block.
lockBlockNoException(long, long) - Method in interface alluxio.worker.block.BlockStore
Locks an existing block and guards subsequent reads on this block.
lockBlockNoException(long, long) - Method in interface alluxio.worker.block.BlockWorker
Obtains a read lock the block without throwing an exception.
lockChild(Inode, InodeTree.LockPattern) - Method in class alluxio.master.file.meta.LockedInodePath
Returns a new locked inode path composed of the current path plus the child inode.
lockChild(Inode, InodeTree.LockPattern, String[]) - Method in class alluxio.master.file.meta.LockedInodePath
Efficient version of #lockChild(Inode, LockPattern) for when the child path components are already known.
lockChildByName(String, InodeTree.LockPattern, String[]) - Method in class alluxio.master.file.meta.LockedInodePath
Efficient version of #lockChild(Inode, LockPattern) for when the child path components are already known.
lockDescendant(AlluxioURI, InodeTree.LockPattern) - Method in class alluxio.master.file.meta.LockedInodePath
Locks a descendant of the current path and returns a new locked inode path.
lockEdge(Inode, String, LockMode) - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
lockEdge(Inode, String, LockMode) - Method in interface alluxio.master.file.meta.InodeLockList
Locks an edge leading out of the last inode in the list.
lockEdge(Edge, LockMode, boolean) - Method in class alluxio.master.file.meta.InodeLockManager
Acquires an edge lock.
lockEdge(Inode, String, LockMode) - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
LockedInodePath - Class in alluxio.master.file.meta
This class represents a locked path within the inode tree, starting from the root.
LockedInodePath(AlluxioURI, ReadOnlyInodeStore, InodeLockManager, InodeDirectory, InodeTree.LockPattern, boolean, JournalContext) - Constructor for class alluxio.master.file.meta.LockedInodePath
Creates a new locked inode path.
LockedInodePathList - Class in alluxio.master.file.meta
This class represents a list of locked inodePaths.
LockedInodePathList(List<LockedInodePath>) - Constructor for class alluxio.master.file.meta.LockedInodePathList
Creates a new instance of LockedInodePathList.
lockExclusive(StateLockOptions) - Method in class alluxio.master.StateLockManager
Locks the state exclusively.
lockExclusive(StateLockOptions, RetryUtils.RunnableThrowsIOException) - Method in class alluxio.master.StateLockManager
Locks the state exclusively.
lockFinalEdgeWrite() - Method in class alluxio.master.file.meta.LockedInodePath
Returns a copy of the path with the final edge write locked.
lockForCheckpoint() - Method in class alluxio.rocks.RocksStore
Before the process shuts down, acquire an exclusive lock on the RocksDB before closing.
lockForClosing() - Method in class alluxio.rocks.RocksStore
Before the process shuts down, acquire an exclusive lock on the RocksDB before closing.
lockForRewrite() - Method in class alluxio.rocks.RocksStore
Before the process shuts down, acquire an exclusive lock on the RocksDB before closing.
lockFullInodePath(AlluxioURI, LockingScheme, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks a path and throws an exception if the path does not exist.
lockFullInodePath(AlluxioURI, InodeTree.LockPattern, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks a path and throws an exception if the path does not exist.
lockFullInodePath(long, InodeTree.LockPattern, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks a path and throws an exception if the path does not exist.
LockingScheme - Class in alluxio.master.file.meta
This class represents information about how a path should be locked.
LockingScheme(AlluxioURI, InodeTree.LockPattern, boolean) - Constructor for class alluxio.master.file.meta.LockingScheme
Constructs a LockingScheme.
LockingScheme(AlluxioURI, InodeTree.LockPattern, FileSystemMasterCommonPOptions, UfsSyncPathCache, DescendantType) - Constructor for class alluxio.master.file.meta.LockingScheme
Create a new LockingScheme.
lockInode(Inode, LockMode) - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
lockInode(Inode, LockMode) - Method in interface alluxio.master.file.meta.InodeLockList
Locks the given inode and adds it to the lock list.
lockInode(InodeView, LockMode, boolean) - Method in class alluxio.master.file.meta.InodeLockManager
Acquires an inode lock.
lockInode(Long, LockMode) - Method in class alluxio.master.file.meta.InodeLockManager
Acquires an inode lock using Lock.lock().
lockInode(Inode, LockMode) - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
lockInodePath(LockingScheme, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the path and with the pattern defined by LockingScheme.getPath() and LockingScheme.getPattern().
lockInodePath(AlluxioURI, InodeTree.LockPattern, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the specified path, in the specified InodeTree.LockPattern.
lockInodePath(AlluxioURI, InodeTree.LockPattern, boolean, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the specified path, in the specified InodeTree.LockPattern.
lockInodePathPair(AlluxioURI, InodeTree.LockPattern, AlluxioURI, InodeTree.LockPattern, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the two specified paths.
lockInterruptibly() - Method in class alluxio.master.block.meta.WorkerMetaLock
 
LockMode - Enum in alluxio.concurrent
ReadWriteLock types.
lockPath(AlluxioURI) - Method in class alluxio.master.file.MetadataSyncLockManager
Acquire locks for a given path before metadata sync.
LockPool<K> - Class in alluxio.collections
A resource pool specifically designed to contain locks and will NOT evict any entries that are in use.
LockPool(Function<? super K, ? extends ReentrantReadWriteLock>, int, int, int, int) - Constructor for class alluxio.collections.LockPool
Constructor for a lock pool.
LockResource - Class in alluxio.resource
A resource lock that makes it possible to acquire and release locks using the following idiom:
LockResource(Lock) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
LockResource(Lock, boolean, boolean) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
LockResource(Lock, boolean, boolean, Runnable) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
lockRootEdge(LockMode) - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
lockRootEdge(LockMode) - Method in interface alluxio.master.file.meta.InodeLockList
Locks the root edge in the specified mode.
lockRootEdge(LockMode) - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
lockShared() - Method in class alluxio.master.StateLockManager
Locks the state shared.
lockUpdate(long) - Method in class alluxio.master.file.meta.InodeLockManager
Acquires the lock for modifying an inode's last modified time or size.
lockWorkerMeta(EnumSet<WorkerMetaLockSection>, boolean) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Locks the corresponding locks on the metadata groups.
lockWorkerMetaForInfo(Set<GetWorkerReportOptions.WorkerInfoField>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Finds the read locks necessary for required worker information.
LOG - Static variable in class alluxio.client.block.stream.DataWriter.Factory
 
LOG - Static variable in interface alluxio.client.file.cache.CacheManager
 
LOG - Static variable in interface alluxio.client.file.cache.PageStore
 
LOG - Static variable in interface alluxio.client.file.cache.store.PageStoreDir
 
LOG - Static variable in class alluxio.master.file.async.AsyncPersistHandler.Factory
 
LOG - Static variable in interface alluxio.master.journal.checkpoint.Checkpointed
 
LOG - Static variable in interface alluxio.master.metastore.InodeStore
 
LOG - Static variable in class alluxio.master.service.jvmmonitor.JvmMonitorService
 
LOG - Static variable in class alluxio.master.service.metrics.MetricsService
 
LOG - Static variable in class alluxio.master.service.rpc.RpcServerService
 
LOG - Static variable in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
LOG - Static variable in class alluxio.master.service.web.WebServerService
 
LOG - Static variable in class alluxio.underfs.ObjectLowLevelOutputStream
 
LOG - Static variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
LOG - Static variable in interface alluxio.uri.Authority
 
LOG_ARGUMENT_LEVEL - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
LOG_ARGUMENT_LEVEL - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_ARGUMENT_LEVEL - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
LOG_ARGUMENT_NAME - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
LOG_ARGUMENT_NAME - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_ARGUMENT_NAME - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
LOG_LEVEL - Static variable in class alluxio.cli.LogLevel
 
LOG_LEVEL - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
LOG_LEVEL - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
LOG_LEVEL - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
logAccess(HttpServletRequest, HttpServletResponse, Stopwatch, S3BaseTask.OpType) - Static method in class alluxio.web.ProxyWebServer
Log the access of every single http request.
logAccess(HttpRequest, HttpResponse, Stopwatch, S3NettyBaseTask.OpType) - Static method in class alluxio.worker.s3.S3NettyHandler
Log the access of every single http request.
logAllThreads() - Static method in class alluxio.util.ThreadUtils
Logs a stack trace for all threads currently running in the JVM, similar to jstack.
logCompleted() - Method in class alluxio.cli.fs.command.job.JobAttempt
 
logConfigReport() - Method in class alluxio.master.meta.checkconf.ConfigurationChecker
Logs the configuration check report information.
logFailed() - Method in class alluxio.cli.fs.command.job.JobAttempt
 
logFailedAttempt(JobInfo) - Method in class alluxio.cli.fs.command.job.JobAttempt
 
Logged - Annotation Type in alluxio.proxy.s3.logging
Helper interface to add to request methods that needs logging for debugging.
LOGGER_TYPE - Static variable in class alluxio.conf.PropertyKey
 
LOGGER_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
LOGICAL_MASTER_AUTH - Static variable in interface alluxio.uri.Authority
 
LOGICAL_ZOOKEEPER_AUTH - Static variable in interface alluxio.uri.Authority
 
login() - Method in class alluxio.security.login.AlluxioLoginModule
Authenticates the user (first phase).
login() - Method in class alluxio.security.login.AppLoginModule
Retrieves the user name by querying the property of PropertyKey.SECURITY_LOGIN_USERNAME through AppLoginModule.AppCallbackHandler.
login() - Method in class alluxio.security.user.BaseUserState
 
login() - Method in class alluxio.security.user.NoopUserState
 
login() - Method in class alluxio.security.user.SimpleUserState
 
LogInfo - Class in alluxio.wire
Information about the LogInfo.
LogInfo() - Constructor for class alluxio.wire.LogInfo
Creates a new instance of LogInfo.
LoginModuleConfiguration - Class in alluxio.security.login
A JAAS configuration that defines the login modules, by which JAAS uses to login.
LoginModuleConfiguration() - Constructor for class alluxio.security.login.LoginModuleConfiguration
Constructs a new LoginModuleConfiguration.
LoginModuleConfigurationUtils - Class in alluxio.security.login
This class provides constants used in JAAS login.
LogLevel - Class in alluxio.cli
Sets or gets the log level for the specified server.
logLevel(String[], AlluxioConfiguration) - Static method in class alluxio.cli.LogLevel
Implements log level setting and getting.
logLevel(String, String) - Method in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
logLevel(String, String) - Method in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
logLevel(String, String) - Method in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
LogLevel.TargetInfo - Class in alluxio.cli
Object that represents a REST endpoint that logLevel sends HTTP request to.
logout() - Method in class alluxio.security.login.AlluxioLoginModule
Logs out the user.
logout() - Method in class alluxio.security.login.AppLoginModule
Logs out the user
logPerIteration(long, int, String, int) - Static method in class alluxio.examples.Performance
Writes log information.
logProgress() - Method in class alluxio.master.journal.AbstractJournalProgressLogger
Logs the progress of journal replay.
LOGS_DIR - Static variable in class alluxio.conf.PropertyKey
 
LOGS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
logThreadInfo(Logger, String, long) - Static method in class alluxio.util.ThreadUtils
Log the current thread stacks at INFO level.
LogUtils - Class in alluxio.util
Utility methods for working with log.
LONG_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
LONG_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Value
 
longBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
LongCheckpointFormat - Class in alluxio.master.journal.checkpoint
Format for checkpoints containing a single long.
LongCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.LongCheckpointFormat
 
LongCheckpointFormat.LongCheckpointReader - Class in alluxio.master.journal.checkpoint
Reads a checkpoint containing a single long.
LongCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.LongCheckpointFormat.LongCheckpointReader
 
LongColumnStatsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.LongColumnStatsData
LongColumnStatsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.LongColumnStatsData
LongColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
 
LONGESTRUNNING_FIELD_NUMBER - Static variable in class alluxio.grpc.JobServiceSummary
 
LongsCheckpointFormat - Class in alluxio.master.journal.checkpoint
Format for checkpoints consisting of a list of longs written by a DataOutputStream.
LongsCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.LongsCheckpointFormat
 
LongsCheckpointFormat.LongsCheckpointReader - Class in alluxio.master.journal.checkpoint
Reads a checkpoint of longs.
LongsCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.LongsCheckpointFormat.LongsCheckpointReader
 
longValue() - Method in enum alluxio.jnifuse.constants.Errno
 
lookup(PropertyKey, String) - Method in class alluxio.conf.InstancedConfiguration
Lookup key names to handle ${key} stuff.
lookupRecursively(PropertyKey, String, Set<String>) - Method in class alluxio.conf.InstancedConfiguration
Actual recursive lookup replacement.
losePrimacy() - Method in interface alluxio.master.journal.JournalSystem
Transitions the journal to standby mode.
losePrimacy() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
losePrimacy() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
losePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
LOSEPRIMACYTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobMasterPOptions
 
LOSEPRIMACYTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPOptions
 
LOST_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
LOST_VALUE - Static variable in enum alluxio.grpc.WorkerRange
LOST = 3;
LOST_WORKER_NUM_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
LOST_WORKER_NUM = 5;
lostNodeFound(Address) - Method in class alluxio.master.meta.checkconf.ConfigurationStore
Updates configuration when a lost node is found.
LOSTSTORAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
 
LOSTSTORAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
LOSTSTORAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerLostStorageInfo
 
LostWorkerDetectionHeartbeatExecutor() - Constructor for class alluxio.master.block.DefaultBlockMaster.LostWorkerDetectionHeartbeatExecutor
LOSTWORKERNUM_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
LOW_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Range
 
LOW_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DateColumnStatsData
 
LOW_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DecimalColumnStatsData
 
LOW_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DoubleColumnStatsData
 
LOW_VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LongColumnStatsData
 
LRUCacheEvictor - Class in alluxio.client.file.cache.evictor
LRU client-side cache eviction policy.
LRUCacheEvictor(CacheEvictorOptions) - Constructor for class alluxio.client.file.cache.evictor.LRUCacheEvictor
Constructor.
LS_FORMAT - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_ALLUXIO_STATE - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_FILE_PATH - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_FILE_SIZE - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_GROUP_NAME - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_NO_ACL - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_PERMISSION - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_PERSISTENCE_STATE - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_TIMESTAMP - Static variable in class alluxio.cli.fs.command.LsCommand
 
LS_FORMAT_USER_NAME - Static variable in class alluxio.cli.fs.command.LsCommand
 
LsCommand - Class in alluxio.cli.extensions.command
Lists all installed extensions.
LsCommand() - Constructor for class alluxio.cli.extensions.command.LsCommand
Constructs a new instance of LsCommand.
LsCommand - Class in alluxio.cli.fs.command
Displays information for the path specified in args.
LsCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.LsCommand
Constructs a new instance to display information for all directories and files directly under the path specified in args.

M

MACFUSE_SUPPORT_MINIMUM_OS_VERSION - Static variable in class alluxio.fuse.AlluxioFuseUtils
 
mAcl - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mAcl - Variable in class alluxio.master.file.meta.MutableInode
 
mActiveJobs - Variable in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
mActiveJobs - Variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
mActiveWorkers - Variable in class alluxio.master.scheduler.Scheduler.WorkerInfoHub
 
main(String[]) - Static method in class alluxio.cli.BasicCheckpoint
Example program for using checkpoints.
main(String[]) - Static method in class alluxio.cli.bundler.CollectInfo
Main method, starts a new CollectInfo shell.
main(String[]) - Static method in class alluxio.cli.CheckCluster
Main function to test the cluster setup.
main(String[]) - Static method in class alluxio.cli.DocGenerator
Main entry for this util class.
main(String[]) - Static method in class alluxio.cli.extensions.ExtensionsShell
Manage Alluxio extensions.
main(String[]) - Static method in class alluxio.cli.Format
Formats the Alluxio file system.
main(String[]) - Static method in class alluxio.cli.fs.FileSystemShell
Main method, starts a new FileSystemShell.
main(String[]) - Static method in class alluxio.cli.fsadmin.FileSystemAdminShell
Manage Alluxio file system.
main(String[]) - Static method in class alluxio.cli.GetConf
Prints Alluxio configuration.
main(String[]) - Static method in class alluxio.cli.LogLevel
Sets or gets log level of master and worker through their REST API.
main(String[]) - Static method in class alluxio.cli.MiniBenchmark
 
main(String[]) - Static method in class alluxio.cli.RunOperation
Tool for running an operation multiple times.
main(String[]) - Static method in class alluxio.cli.TestRunner
Console program that validates the configuration.
main(String[]) - Static method in class alluxio.cli.UnderFileSystemContractTest
 
main(String[]) - Static method in class alluxio.cli.ValidateConf
Console program that validates the configuration.
main(String[]) - Static method in class alluxio.cli.ValidateEnv
Validates Alluxio environment.
main(String[]) - Static method in class alluxio.cli.ValidateHdfsMount
The entrance.
main(String[]) - Static method in class alluxio.cli.Version
Prints the version of the current build.
main(String[]) - Static method in class alluxio.dora.meta.DoraMetaBench
 
main(String[]) - Static method in class alluxio.examples.AlluxioFS
Entry point for the AlluxioFS program.
main(String[]) - Static method in class alluxio.examples.AlluxioHDFS
Entry point for the AlluxioHDFS program.
main(String[]) - Static method in class alluxio.examples.HDFS
Entry point for the HDFS program.
main(String[]) - Static method in class alluxio.examples.MultiMount
Entry point for the MultiMount program.
main(String[]) - Static method in class alluxio.examples.Performance
Runs the performance test.
main(String[]) - Static method in class alluxio.fsmaster.BenchStandaloneGrpcServer
This main function can be used to start a standalone server and use the stressbench with said standalone server.
main(String[]) - Static method in class alluxio.fsmaster.FileSystemBench
 
main(String[]) - Static method in class alluxio.fsmaster.FileSystemMasterBench
 
main(String[]) - Static method in class alluxio.fuse.AlluxioFuse
Running this class will mount the file system according to the options passed to this function.
main(String[]) - Static method in class alluxio.fuse.StackMain
 
main(String[]) - Static method in class alluxio.inode.InodeBenchRead
 
main(String[]) - Static method in class alluxio.inode.InodeBenchWrite
 
main(String[]) - Static method in class alluxio.inode.RocksBenchRead
 
main(String[]) - Static method in class alluxio.inode.RocksBenchReadWrite
 
main(String[]) - Static method in class alluxio.inode.RocksBenchWrite
 
main(String[]) - Static method in class alluxio.invalidation.cache.InvalidationSyncCacheBench
 
main(String[]) - Static method in class alluxio.master.AlluxioJobMaster
Starts the Alluxio job master.
main(String[]) - Static method in class alluxio.master.AlluxioMaster
Starts the Alluxio master.
main(String[]) - Static method in class alluxio.master.AlluxioMasterMonitor
Starts the Alluxio master monitor.
main(String[]) - Static method in class alluxio.master.backcompat.BackwardsCompatibilityJournalGenerator
Generates journal files to be used by the backwards compatibility test.
main(String[]) - Static method in class alluxio.master.job.AlluxioJobMasterMonitor
Starts the Alluxio job_master monitor.
main(String[]) - Static method in class alluxio.master.journal.tool.JournalTool
Dumps a ufs journal in human-readable format.
main(String[]) - Static method in class alluxio.master.journalv0.JournalTool
Reads a journal via java -cp \ assembly/server/target/alluxio-assembly-server-<ALLUXIO-VERSION>-jar-with-dependencies.jar \ alluxio.master.journal.JournalTool < journal/FileSystemMaster/log.out.
main(String[]) - Static method in class alluxio.multi.process.LimitedLifeMasterProcess
 
main(String[]) - Static method in class alluxio.multi.process.LimitedLifeWorkerProcess
 
main(String[]) - Static method in class alluxio.proxy.AlluxioProxy
Starts the Alluxio proxy.
main(String[]) - Static method in class alluxio.proxy.AlluxioProxyMonitor
Starts the Alluxio proxy monitor.
main(String[]) - Static method in class alluxio.RpcUtilsBench
 
main(String[]) - Static method in class alluxio.snapshot.SnapshotBench
 
main(String[]) - Static method in class alluxio.stress.cli.client.StressClientIOBench
 
main(String[]) - Static method in class alluxio.stress.cli.report.GenerateReport
 
main(String[]) - Static method in class alluxio.stress.cli.UfsIOBench
 
main(String[]) - Static method in class alluxio.stress.cli.worker.StressWorkerBench
 
main(String[]) - Static method in class alluxio.util.HFSUtils
The main class to invoke the getNumSector.
main(String[]) - Static method in class alluxio.worker.AlluxioJobWorker
Starts the Alluxio job worker.
main(String[]) - Static method in class alluxio.worker.AlluxioWorker
Starts the Alluxio worker.
main(String[]) - Static method in class alluxio.worker.AlluxioWorkerMonitor
Starts the Alluxio worker monitor.
main(String[]) - Static method in class alluxio.worker.job.AlluxioJobWorkerMonitor
Starts the Alluxio job_worker monitor.
mainInternal(String[], Benchmark) - Static method in class alluxio.stress.cli.Benchmark
 
makeTag(int, int) - Static method in class alluxio.grpc.GrpcSerializationUtils
Makes a gRPC tag for a field.
makeValuesSerializable(Map<S, Collection<T>>) - Static method in class alluxio.job.util.SerializationUtils
 
MALFORMED_XML - Static variable in class alluxio.s3.S3ErrorCode
 
MALFORMED_XML - Static variable in class alluxio.s3.S3ErrorCode.Name
 
mAlluxioConf - Variable in class alluxio.hadoop.AbstractFileSystem
 
mAlwaysEnableTLS - Variable in class alluxio.AbstractClient
 
managedBlock(ForkJoinPool.ManagedBlocker) - Static method in class alluxio.concurrent.jsr.ForkJoinPool
Runs the given possibly blocking task.
ManagedBlockingUfsForwarder - Class in alluxio.concurrent
Forwarder for UnderFileSystem objects that works through with ForkJoinPool's managed blocking.
ManagedBlockingUfsForwarder(UnderFileSystem) - Constructor for class alluxio.concurrent.ManagedBlockingUfsForwarder
Creates ManagedBlockingUfsForwarder instance.
map(Function<T, R>, Collection<T>) - Static method in class alluxio.util.StreamUtils
 
mark(int) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
markAllBlocksToRemove() - Method in class alluxio.master.block.meta.MasterWorkerInfo
Marks all the blocks on the worker to be removed.
markOutdated() - Method in class alluxio.conf.Hash
Called when the version needs to be updated.
markSupported() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
markSupported() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
mask(AclActions) - Method in class alluxio.security.authorization.AclActions
Mask the actions.
MASK_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
Mask_VALUE - Static variable in enum alluxio.grpc.PAclEntryType
Mask = 4;
MASK_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclEntryType
MASK = 4;
MASKACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
maskObjects(Logger, Object...) - Method in interface alluxio.conf.SensitiveConfigMask
Copy and mask objects' sensitive information.
maskObjects(Logger, Object...) - Method in class alluxio.RpcSensitiveConfigMask
 
Master - Interface in alluxio.master
This interface contains common operations for all masters.
Master - Class in alluxio.multi.process
Class for running and interacting with an Alluxio master in a separate process.
Master(File, Map<PropertyKey, Object>) - Constructor for class alluxio.multi.process.Master
 
MASTER_ABSENT_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ABSENT_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ABSENT_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ABSENT_PATH_CACHE_QUEUE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ACTIVE_UFS_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_ADDRESSES_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
MASTER_ADDRESSES = 1;
MASTER_ASYNC_PERSIST_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_SIZE_VALIDATION - Static variable in class alluxio.conf.PropertyKey
Master related properties.
MASTER_ASYNC_PERSIST_SIZE_VALIDATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_ASYNC_PERSIST_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_AUDIT_LOG_ENTRIES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_AUDIT_LOGGING_QUEUE_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_AUDIT_LOGGING_QUEUE_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_ABANDON_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_ABANDON_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_CONNECT_INTERVAL_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_CONNECT_INTERVAL_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_CONNECT_INTERVAL_MIN - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_CONNECT_INTERVAL_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_DELEGATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_DELEGATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_DIRECTORY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_DIRECTORY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_ENTRY_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_ENTRY_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_EXCLUSIVE_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_EXCLUSIVE_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_FORCED_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_FORCED_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_SUSPEND_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_SUSPEND_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_TRANSPORT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_TRANSPORT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BLOCK_HEAP_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_BLOCK_METASTORE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BLOCK_SCAN_INVALID_BATCH_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BLOCK_SCAN_INVALID_BATCH_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_CACHED_BLOCK_LOCATIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_CHECKPOINT_SCHEDULING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_CLUSTER_METRICS_UPDATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_CLUSTER_METRICS_UPDATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_CLUSTER_METRICS_UPDATER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_COLUMN_FILE_PREFIX - Static variable in class alluxio.Constants
 
MASTER_COMMAND_SESSION_ID - Static variable in class alluxio.Sessions
 
MASTER_COMPLETE_FILE_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_COMPLETED_OPERATION_RETRY_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_CONTAINER_ID_RESERVATION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_CONTAINER_ID_RESERVATION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_CREATE_DIRECTORIES_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_CREATE_FILES_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_DAILY_BACKUP - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_DAILY_BACKUP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_FILES_RETAINED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_FILES_RETAINED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DELETE_PATHS_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_DIRECTORIES_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_DORA_LOAD_JOB_RETRIES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DORA_LOAD_JOB_RETRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DORA_LOAD_JOB_TOTAL_FAILURE_COUNT_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DORA_LOAD_JOB_TOTAL_FAILURE_COUNT_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DORA_LOAD_JOB_TOTAL_FAILURE_RATIO_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DORA_LOAD_JOB_TOTAL_FAILURE_RATIO_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EDGE_CACHE_EVICTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_LOAD_TIMES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_LOCK_POOL_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_CATCHUP_RETRY_WAIT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_CATCHUP_RETRY_WAIT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_ENTRY_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_ENTRY_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_FLUSH_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_FLUSH_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_DOWNLOAD_DISK_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_DOWNLOAD_DURATION_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_DOWNLOAD_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_DURATION_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_ENTRIES_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_REPLAY_DURATION_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_REPLAY_ENTRIES_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_UPLOAD_DISK_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_UPLOAD_DURATION_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_LAST_SNAPSHOT_UPLOAD_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_MAX_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_MAX_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_MIN_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_MIN_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RATIS_CONFIG - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RATIS_CONFIG - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RETRY_CACHE_EXPIRY_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RETRY_CACHE_EXPIRY_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_DOWNLOAD_DISK_HISTOGRAM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_DOWNLOAD_HISTOGRAM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_DOWNLOAD_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_GENERATE_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_INSTALL_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_LAST_INDEX - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLAY_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_COMPRESSION_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_COMPRESSION_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_COMPRESSION_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_COMPRESSION_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_UPLOAD_DISK_HISTOGRAM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_UPLOAD_HISTOGRAM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_UPLOAD_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_REQUEST_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_REQUEST_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_UNSAFE_FLUSH_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_UNSAFE_FLUSH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_WRITE_REMOTE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_WRITE_REMOTE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FAILOVER_COLLECT_INFO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FAILOVER_COLLECT_INFO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_BLOCK_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_RECOMPUTATION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_SYSTEM_LISTSTATUS_RESULTS_PER_MESSAGE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_LISTSTATUS_RESULTS_PER_MESSAGE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_SYSTEM_MERGE_INODE_JOURNALS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_MERGE_INODE_JOURNALS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILES_COMPLETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_FREED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_PERSISTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_PINNED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_TO_PERSIST - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FORMAT_FILE_PREFIX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FORMAT_FILE_PREFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FREE_FILE_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_FILE_BLOCK_INFO_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_FILE_INFO_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_NEW_BLOCK_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_HEARTBEAT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_HEARTBEAT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_INODE_CACHE_EVICTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_HIT_RATIO - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_LOAD_TIMES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_HEAP_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_LOCK_POOL_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_METASTORE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOB_CANCELED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COMPLETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_FAIL_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_RATE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_SKIP_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_FAILED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_BLOCK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_BLOCK_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_BLOCK_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FILE_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_RATE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_MOVE_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_MOVE_FAIL_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_MOVE_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_MOVE_RATE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_MOVE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_MOVE_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_RUNNING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_SCHEDULER_RUNNING_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_BACKUP_WHEN_CORRUPTED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_BACKUP_WHEN_CORRUPTED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_CATCHUP_PROTECT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_CATCHUP_PROTECT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_CHECKPOINT_PERIOD_ENTRIES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_CHECKPOINT_PERIOD_ENTRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_CHECKPOINT_WARN - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_ENTRIES_SINCE_CHECKPOINT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_EXIT_ON_DEMOTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_EXIT_ON_DEMOTION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_BATCH_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FLUSH_BATCH_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_FAILURE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_FLUSH_RETRY_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FLUSH_RETRY_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FLUSH_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_FOLDER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FOLDER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_GAIN_PRIMACY_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_GC_PERIOD_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_GC_PERIOD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_LAST_APPLIED_COMMIT_INDEX - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_LAST_CHECKPOINT_TIME - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_LOCAL_LOG_COMPACTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_LOCAL_LOG_COMPACTION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_LOG_SIZE_BYTES_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_LOG_SIZE_BYTES_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_REQUEST_INFO_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_REQUEST_INFO_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_SEQUENCE_NUMBER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_SPACE_FREE_BYTES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_SPACE_FREE_PERCENT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_SPACE_MONITOR - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_JOURNAL_SPACE_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_SPACE_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_SPACE_MONITOR_PERCENT_FREE_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_SPACE_MONITOR_PERCENT_FREE_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_SYNC_ROOT_AFTER_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_SYNC_ROOT_AFTER_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TAILER_SHUTDOWN_QUIET_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TAILER_SHUTDOWN_QUIET_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TAILER_SLEEP_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TAILER_SLEEP_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TEMPORARY_FILE_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TEMPORARY_FILE_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TOLERATE_CORRUPTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TOLERATE_CORRUPTION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_UFS_OPTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_KEYTAB_KEY_FILE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_KEYTAB_KEY_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LAST_BACKUP_ENTRIES_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_RESTORE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_RESTORE_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_GAIN_PRIMACY_TIME - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_LOSE_PRIMACY_TIME - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_EVICTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_LOAD_TIMES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOG_CONFIG_REPORT_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOG_CONFIG_REPORT_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOG_CONFIG_REPORT_SCHEDULING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_BLOCK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LOST_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LOST_FILES_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_MASTER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_PROXY_DELETION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOST_PROXY_DELETION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOST_PROXY_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_WORKER_DELETION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOST_WORKER_DELETION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOST_WORKER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_WORKER_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOST_WORKER_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOST_WORKER_FILE_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOST_WORKER_FILE_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_MERGE_JOURNAL_CONTEXT_NUM_ENTRIES_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MERGE_JOURNAL_CONTEXT_NUM_ENTRIES_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_CONCURRENT_SYNC_DEDUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_CONCURRENT_SYNC_DEDUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_ACTIVE_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_EXECUTOR - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_EXECUTOR_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_EXECUTOR_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_EXECUTOR_QUEUE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_GET_DIRECTORY_STATUS_SKIP_LOADING_CHILDREN - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_GET_DIRECTORY_STATUS_SKIP_LOADING_CHILDREN - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_IGNORE_TTL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_IGNORE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_INSTRUMENT_EXECUTOR - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_INSTRUMENT_EXECUTOR - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_NO_CHANGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_OPS_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PATHS_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PATHS_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PATHS_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PENDING_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_EXECUTOR - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_EXECUTOR_QUEUE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_OPS_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_RETRIES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_REPORT_FAILURE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_REPORT_FAILURE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_SKIPPED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_TRAVERSAL_ORDER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_TRAVERSAL_ORDER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_UFS_MOUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_UFS_PREFETCH_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_UFS_PREFETCH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_BLOCK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_DIR_BLOCK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_DIR_BLOCK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_DIR_INODE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_DIR_INODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_EVICT_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_EVICT_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_HIGH_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_HIGH_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_LOW_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_LOW_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_ENUMERATOR_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_ENUMERATOR_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_INHERIT_OWNER_AND_GROUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_INHERIT_OWNER_AND_GROUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_ITERATION_CRAWLER_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_ITERATION_CRAWLER_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ITERATOR_READAHEAD_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ITERATOR_READAHEAD_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_METRICS_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_METRICS_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_CHECKPOINT_COMPRESSION_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_CHECKPOINT_COMPRESSION_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_CHECKPOINT_COMPRESSION_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EXCLUSIVE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EXCLUSIVE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP_THREADS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_FILE_SIZE_DISTRIBUTION_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_FILE_SIZE_DISTRIBUTION_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_HEAP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_HEAP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_METRICS_TIME_SERIES - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_METRICS_TIME_SERIES_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_TIME_SERIES_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_MIGRATE_JOB_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MOUNT_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MOUNT_TABLE_ROOT_ALLUXIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_OPTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_READONLY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_UFS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NEW_BLOCKS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ORPHANED_METRICS_CLEANER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_PATHS_DELETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_MOUNTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_RENAMED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_UNMOUNTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PERSISTENCE_BLACKLIST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_BLACKLIST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_CHECKER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_PERSISTENCE_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_INITIAL_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_INITIAL_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_MAX_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_MAX_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_MAX_TOTAL_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_MAX_TOTAL_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_SCHEDULER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_PERSISTENCE_SCHEDULER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_SCHEDULER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PROXY_CHECK_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PROXY_CHECK_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PROXY_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PROXY_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RECURSIVE_OPERATION_JOURNAL_FORCE_FLUSH_MAX_ENTRIES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RECURSIVE_OPERATION_JOURNAL_FORCE_FLUSH_MAX_ENTRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RENAME_PATH_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_REPLICA_MGMT_ACTIVE_JOB_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_REPLICATION_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_REPLICATION_LIMITED_FILES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_BACKGROUND_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_BLOCK_CACHE_CAPACITY - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_BLOCK_CACHE_PINNED_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_BLOCK_CACHE_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_COMPACTION_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_CUR_SIZE_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_CUR_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATE_NUM_KEYS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATE_PENDING_COMPACTION_BYTES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATE_TABLE_READERS_MEM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATED_MEM_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_LIVE_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_MEM_TABLE_FLUSH_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_DELETES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_DELETES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_ENTRIES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_ENTRIES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_IMMUTABLE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_LIVE_VERSIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_RUNNING_COMPACTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_RUNNING_FLUSHES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_TOTAL_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BACKGROUND_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BLOCK_CACHE_CAPACITY - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BLOCK_CACHE_PINNED_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BLOCK_CACHE_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_COMPACTION_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_CUR_SIZE_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_CUR_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATE_NUM_KEYS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATE_PENDING_COMPACTION_BYTES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATE_TABLE_READERS_MEM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATED_MEM_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_LIVE_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_MEM_TABLE_FLUSH_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_DELETES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_DELETES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_ENTRIES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_ENTRIES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_IMMUTABLE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_LIVE_VERSIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_RUNNING_COMPACTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_RUNNING_FLUSHES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_TOTAL_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_TOTAL_ESTIMATED_MEM_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROLE_ID - Static variable in class alluxio.metrics.MetricKey
 
MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_QUEUE_LENGTH - Static variable in class alluxio.metrics.MetricKey
 
MASTER_RPC_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_RPC_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SCHEDULER_INITIAL_DELAY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SCHEDULER_INITIAL_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SCHEDULER_RESTORE_JOB_FROM_JOURNAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SCHEDULER_RESTORE_JOB_FROM_JOURNAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SERVICE_PREFIX - Static variable in class alluxio.job.ServiceConstants
 
MASTER_SET_ACL_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SET_ATTRIBUTE_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SKIP_ROOT_ACL_CHECK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SKIP_ROOT_ACL_CHECK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_STANDBY_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_STANDBY_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_START_TIME - Static variable in class alluxio.metrics.MetricKey
 
MASTER_STATE_LOCK_ERROR_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
MASTER_STATE_LOCK_ERROR_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TABLE_TRANSFORMATION_MONITOR - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_THROTTLE - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TO_REMOVE_BLOCK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TOTAL_BLOCK_REPLICA_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TOTAL_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TOTAL_RPCS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TTL_BUCKETS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TTL_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TTL_INODES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_JOURNAL_CATCHUP_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_JOURNAL_FAILURE_RECOVER_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_JOURNAL_INITIAL_REPLAY_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_JOURNAL_MAX_CATCHUP_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_JOURNAL_MAX_CATCHUP_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_MANAGED_BLOCKING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_MANAGED_BLOCKING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_PATH_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_PATH_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_PATH_CACHE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_PATH_CACHE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_STATUS_CACHE_CHILDREN_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_STATUS_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UNIQUE_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UNMOUNT_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UNSAFE_DIRECT_PERSIST_OBJECT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UNSAFE_DIRECT_PERSIST_OBJECT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UPDATE_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_UPDATE_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UPDATE_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UPDATE_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UPDATE_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_VALUE - Static variable in enum alluxio.grpc.JournalDomain
MASTER = 1;
MASTER_VALUE - Static variable in enum alluxio.grpc.Scope
MASTER = 1;
MASTER_VERSION_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
MASTER_VERSION = 13;
MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_IN_ALLUXIO_DATA_PAGE_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_IN_ALLUXIO_DATA_PAGE_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_JOURNAL_CHECKPOINT_WARNING_THRESHOLD_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_JOURNAL_CHECKPOINT_WARNING_THRESHOLD_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WHITELIST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WHITELIST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_CONNECT_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_CONNECT_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_INFO_CACHE_REFRESH_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_INFO_CACHE_REFRESH_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_RESPECT_JVM_SPACE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_RESPECT_JVM_SPACE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_TTL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_SESSION_CLEANER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobMasterIdPRequest
 
MASTERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMasterIdPRequest
 
MASTERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterStatus
 
MASTERADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
MasterBlockLocation - Class in alluxio.master.block.meta
The location of an Alluxio block.
MasterClientContext - Class in alluxio.master
Configuration for constructing an Alluxio master client.
MasterClientContext(ClientContext, MasterInquireClient) - Constructor for class alluxio.master.MasterClientContext
 
MasterClientContextBuilder - Class in alluxio.master
This class can be used to obtain instances of a MasterClientContext.
MasterClientContextBuilder(ClientContext) - Constructor for class alluxio.master.MasterClientContextBuilder
Create an instance of a MasterClientContextBuilder.
MasterContext<T extends UfsManager> - Class in alluxio.master
Stores context information for Alluxio masters.
MasterContext(JournalSystem, PrimarySelector, T) - Constructor for class alluxio.master.MasterContext
Creates a new master context, using the global server UserState.
MasterContext(JournalSystem, PrimarySelector, UserState, T) - Constructor for class alluxio.master.MasterContext
Creates a new master context.
MasterFactory<T extends MasterContext> - Interface in alluxio.master
Interface for factory of Master.
MasterHealthCheckClient - Class in alluxio.master
MasterHealthCheckClient check whether Alluxio master is serving RPC requests and if the AlluxioMaster process is running in all master hosts.
MasterHealthCheckClient(MasterHealthCheckClient.MasterType, boolean, Supplier<RetryPolicy>, AlluxioConfiguration) - Constructor for class alluxio.master.MasterHealthCheckClient
Creates a new instance of MasterHealthCheckClient.
MasterHealthCheckClient.Builder - Class in alluxio.master
MasterHealthCheckClient.MasterServingHealthCheck - Class in alluxio.master
Runnable for checking if the AlluxioMaster is serving RPCs.
MasterHealthCheckClient.MasterType - Enum in alluxio.master
An enum mapping master types to fully qualified class names.
MasterHealthCheckClient.ProcessCheckRunnable - Class in alluxio.master
Runnable for checking if the AlluxioMaster process are running in all the masters hosts.
masterHeartbeat(JobMasterHeartbeatPRequest, StreamObserver<JobMasterHeartbeatPResponse>) - Method in interface alluxio.grpc.JobMasterMasterServiceGrpc.AsyncService
Heartbeats to indicate the master is lost or not.
masterHeartbeat(JobMasterHeartbeatPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceBlockingStub
Heartbeats to indicate the master is lost or not.
masterHeartbeat(JobMasterHeartbeatPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceFutureStub
Heartbeats to indicate the master is lost or not.
masterHeartbeat(JobMasterHeartbeatPRequest, StreamObserver<JobMasterHeartbeatPResponse>) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceStub
Heartbeats to indicate the master is lost or not.
masterHeartbeat(MasterHeartbeatPRequest, StreamObserver<MasterHeartbeatPResponse>) - Method in interface alluxio.grpc.MetaMasterMasterServiceGrpc.AsyncService
Heartbeats to indicate the master is lost or not.
masterHeartbeat(MasterHeartbeatPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceBlockingStub
Heartbeats to indicate the master is lost or not.
masterHeartbeat(MasterHeartbeatPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceFutureStub
Heartbeats to indicate the master is lost or not.
masterHeartbeat(MasterHeartbeatPRequest, StreamObserver<MasterHeartbeatPResponse>) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub
Heartbeats to indicate the master is lost or not.
masterHeartbeat(long, MasterHeartbeatPOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
 
masterHeartbeat(JobMasterHeartbeatPRequest, StreamObserver<JobMasterHeartbeatPResponse>) - Method in class alluxio.master.meta.JobMasterMasterServiceHandler
 
masterHeartbeat(long, MasterHeartbeatPOptions) - Method in interface alluxio.master.meta.MetaMaster
A standby master periodically heartbeats with the leader master.
masterHeartbeat(MasterHeartbeatPRequest, StreamObserver<MasterHeartbeatPResponse>) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
 
MasterHeartbeatPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterHeartbeatPOptions
MasterHeartbeatPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterHeartbeatPOptions
MasterHeartbeatPOptionsOrBuilder - Interface in alluxio.grpc
 
MasterHeartbeatPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterHeartbeatPRequest
MasterHeartbeatPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterHeartbeatPRequest
MasterHeartbeatPRequestOrBuilder - Interface in alluxio.grpc
 
MasterHeartbeatPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterHeartbeatPResponse
MasterHeartbeatPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterHeartbeatPResponse
MasterHeartbeatPResponseOrBuilder - Interface in alluxio.grpc
 
masterHostConfigured(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
MASTERHOSTNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckpointPResponse
 
MASTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobMasterIdPResponse
 
MASTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMasterIdPResponse
 
MASTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterHeartbeatPRequest
 
MASTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterHeartbeatPRequest
 
MASTERID_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPRequest
 
MasterInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterInfo
MasterInfo - Class in alluxio.master.meta
Master information.
MasterInfo(long, Address) - Constructor for class alluxio.master.meta.MasterInfo
Creates a new instance of MasterInfo.
MasterInfo - Class in alluxio.wire
Master information.
MasterInfo() - Constructor for class alluxio.wire.MasterInfo
Creates a new instance of MasterInfo.
MasterInfo(long, Address) - Constructor for class alluxio.wire.MasterInfo
Creates a new instance of MasterInfo.
MasterInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterInfo
MASTERINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMasterInfoPResponse
 
MasterInfoField - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.meta.MasterInfoField
MasterInfoOrBuilder - Interface in alluxio.grpc
 
MasterInquireClient - Interface in alluxio.master
Client for determining the primary master.
MasterInquireClient.ConnectDetails - Interface in alluxio.master
Interface for representing master inquire connect details.
MasterInquireClient.Factory - Class in alluxio.master
Factory for getting a master inquire client.
MasterJournalContext - Class in alluxio.master.journal
Context for storing master journal information.
MasterJournalContext(AsyncJournalWriter) - Constructor for class alluxio.master.journal.MasterJournalContext
Constructs a MasterJournalContext.
MasterMembershipManager - Class in alluxio.membership
A bypass no-op membership manager to disable MembershipManager module if used, the original way of using master for registration is leveraged for regression compatibility purpose.
MasterMembershipManager() - Constructor for class alluxio.membership.MasterMembershipManager
 
masterMetrics(FileSystemContext) - Static method in class alluxio.cli.bundler.command.CollectMetricsCommand
Get master metrics.
MasterNetAddress - Class in alluxio.multi.process
Network addresses for an Alluxio master.
MasterNetAddress(String, int, int, int) - Constructor for class alluxio.multi.process.MasterNetAddress
 
MasterProcess - Class in alluxio.master
Defines a set of methods which any MasterProcess should implement.
MasterProcess(JournalSystem, PrimarySelector, NetworkAddressUtils.ServiceType, NetworkAddressUtils.ServiceType) - Constructor for class alluxio.master.MasterProcess
Prepares a MasterProcess journal, rpc and web server using the given sockets.
masterRegister(long, RegisterMasterPOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
 
masterRegister(long, RegisterMasterPOptions) - Method in interface alluxio.master.meta.MetaMaster
A standby master registers with the leader master.
MasterRegistry - Class in alluxio.master
A master registry.
MasterRegistry() - Constructor for class alluxio.master.MasterRegistry
Creates a new instance of MasterRegistry.
MasterSelectionPolicy - Interface in alluxio.master.selectionpolicy
Interface for master selection policy that determines which master node a client should connect to.
MasterSelectionPolicy.Factory - Class in alluxio.master.selectionpolicy
MasterSelectionPolicy.Type - Enum in alluxio.master.selectionpolicy
The enum for master selection policies.
MasterServingHealthCheck(InetSocketAddress, ServiceType, Supplier<RetryPolicy>, AlluxioConfiguration) - Constructor for class alluxio.master.MasterHealthCheckClient.MasterServingHealthCheck
Creates a new instance of MasterHealthCheckClient.MasterServingHealthCheck to check for an open RPC port for the given service.
mastersStartedCallback() - Method in class alluxio.master.StateLockManager
This is called by owning process in order to signal that the state is read completely and masters are started.
MasterUfsManager - Class in alluxio.underfs
A class that manages the UFS for master servers.
MasterUfsManager() - Constructor for class alluxio.underfs.MasterUfsManager
 
MasterUtils - Class in alluxio.master
This class encapsulates the different master services that are configured to run.
MasterVersion - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterVersion
MasterVersion.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.MasterVersion
MasterVersionOrBuilder - Interface in alluxio.grpc
 
MASTERVERSIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
MasterWebServer - Class in alluxio.web
The Alluxio master web server.
MasterWebServer(String, InetSocketAddress, AlluxioMasterProcess) - Constructor for class alluxio.web.MasterWebServer
Creates a new instance of MasterWebServer.
MasterWebUIBrowse - Class in alluxio.wire
Alluxio WebUI browse information.
MasterWebUIBrowse() - Constructor for class alluxio.wire.MasterWebUIBrowse
Creates a new instance of MasterWebUIBrowse.
MasterWebUIConfiguration - Class in alluxio.wire
Alluxio WebUI configuration information.
MasterWebUIConfiguration() - Constructor for class alluxio.wire.MasterWebUIConfiguration
Creates a new instance of MasterWebUIConfiguration.
MasterWebUIData - Class in alluxio.wire
Alluxio WebUI memory information.
MasterWebUIData() - Constructor for class alluxio.wire.MasterWebUIData
Creates a new instance of MasterWebUIData.
MasterWebUIInit - Class in alluxio.wire
Alluxio WebUI overview information.
MasterWebUIInit() - Constructor for class alluxio.wire.MasterWebUIInit
Creates a new instance of MasterWebUIInit.
MasterWebUILogs - Class in alluxio.wire
Alluxio WebUI logs information.
MasterWebUILogs() - Constructor for class alluxio.wire.MasterWebUILogs
Creates a new instance of MasterWebUIWorkers.
MasterWebUIMasters - Class in alluxio.wire
Alluxio WebUI masters information.
MasterWebUIMasters() - Constructor for class alluxio.wire.MasterWebUIMasters
Creates a new instance of MasterWebUIMasters.
MasterWebUIMetrics - Class in alluxio.wire
Alluxio WebUI metrics information.
MasterWebUIMetrics() - Constructor for class alluxio.wire.MasterWebUIMetrics
Creates a new instance of MasterWebUIMetrics.
MasterWebUIMountTable - Class in alluxio.wire
Alluxio WebUI mount table information.
MasterWebUIMountTable() - Constructor for class alluxio.wire.MasterWebUIMountTable
Creates a new instance of MasterWebUIMountTable.
MasterWebUIOverview - Class in alluxio.wire
Alluxio WebUI overview information.
MasterWebUIOverview() - Constructor for class alluxio.wire.MasterWebUIOverview
Creates a new instance of MasterWebUIOverview.
MasterWebUIWorkers - Class in alluxio.wire
Alluxio WebUI workers information.
MasterWebUIWorkers() - Constructor for class alluxio.wire.MasterWebUIWorkers
Creates a new instance of MasterWebUIWorkers.
MasterWorkerInfo - Class in alluxio.job
Metadata for an Alluxio worker.
MasterWorkerInfo(long, WorkerNetAddress) - Constructor for class alluxio.job.MasterWorkerInfo
Creates a new instance of MasterWorkerInfo.
MasterWorkerInfo(long, WorkerNetAddress, BuildVersion) - Constructor for class alluxio.job.MasterWorkerInfo
Creates a new instance of MasterWorkerInfo.
MasterWorkerInfo - Class in alluxio.master.block.meta
This class embeds all metadata for an Alluxio worker.
MasterWorkerInfo(long, WorkerNetAddress) - Constructor for class alluxio.master.block.meta.MasterWorkerInfo
Creates a new instance of MasterWorkerInfo.
mAsyncAuditLogWriter - Variable in class alluxio.master.file.DefaultFileSystemMaster
Log writer for user access audit log.
mAsyncAuditLogWriter - Variable in class alluxio.proxy.s3.S3Handler
 
mAsyncAuditLogWriter - Variable in class alluxio.worker.s3.S3NettyHandler
 
mAsyncClient - Variable in class alluxio.worker.block.BlockMasterClient
 
match(String, String) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Returns whether or not filePath matches patternPath.
match(String) - Method in enum alluxio.conf.PropertyKey.Template
 
matchContent(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in the content part.
matches(String) - Method in enum alluxio.client.quota.CacheScope.Level
 
matches(String) - Method in enum alluxio.conf.PropertyKey.Template
 
matches(String, Metric) - Method in class alluxio.metrics.sink.RegexMetricFilter
 
matches(String, String) - Static method in enum alluxio.underfs.hdfs.HdfsVersion
 
matchIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array has a sub array equals an increasing sequence of bytes, starting from 0.
matchIncreasingByteArray(int, int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array has a sub array equals an increasing sequence of bytes, starting from the given value.
matchIncreasingByteBuffer(int, int, ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte buffer has a sub buffer equals an increasing sequence of bytes, starting from the given value.
matchIncreasingByteBuffer(int, int, int, ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte buffer has a sub buffer equals an increasing sequence of bytes, starting from the given value.
matchMetadata(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in metadata.
matchSnapshotPath(Path) - Static method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
mAuthority - Variable in class alluxio.uri.StandardURI
 
mAvgSpeedMbps - Variable in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
MAX_COL_LEN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BinaryColumnStatsData
 
MAX_COL_LEN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.StringColumnStatsData
 
MAX_ENTRIES - Static variable in class alluxio.master.journal.MergeJournalContext
 
MAX_HEADER_METADATA_SIZE - Static variable in class alluxio.proxy.s3.S3Handler
 
MAX_LOG_INTERVAL_MS - Static variable in class alluxio.master.journal.AbstractJournalProgressLogger
Max time to wait before actually logging.
MAX_NAME_LENGTH - Static variable in class alluxio.fuse.AlluxioFuseUtils
Most FileSystems on linux limit the length of file name beyond 255 characters.
MAX_PORT - Static variable in class alluxio.Constants
 
MAX_TEST_DURATION_MS - Static variable in class alluxio.Constants
 
MAX_TEST_PROCESS_LIFETIME_MS - Static variable in class alluxio.Constants
 
MAX_TIME_COUNT - Static variable in class alluxio.stress.StressConstants
 
MAX_TRUNCATED_LENGTH - Static variable in class alluxio.util.LogUtils
The truncated length for a message line.
MAX_TRY - Static variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
MAX_VALUE - Static variable in enum alluxio.jnifuse.constants.Errno
 
MAXIMUM_PART_SIZE - Static variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
The maximum size of a single part is 5GB.
maxInboundMessageSize(int) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the maximum size of inbound messages.
MaxReservoir - Class in alluxio.metrics
A wrapper around Reservoir that keeps track of the max value sent as an update to this reservoir.
MaxReservoir(Reservoir) - Constructor for class alluxio.metrics.MaxReservoir
 
MAXUFSREADCONCURRENCY_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
 
MAXUFSREADCONCURRENCY_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
MB - Static variable in class alluxio.Constants
 
mBackupManager - Variable in class alluxio.master.backup.AbstractBackupRole
Backup Manager.
mBackupManager - Variable in class alluxio.master.CoreMaster
 
mBackupTracker - Variable in class alluxio.master.backup.AbstractBackupRole
Used to track backup status.
mBaseAlias - Variable in class alluxio.stress.client.ClientIOParameters
 
mBaseAlias - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mBaseParameters - Variable in class alluxio.stress.cli.Benchmark
 
mBasePath - Variable in class alluxio.stress.client.ClientIOParameters
 
mBasePath - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mBeanServer - Variable in class alluxio.web.JmxServlet
MBean server.
mBenchTimeout - Variable in class alluxio.stress.BaseParameters
 
mBindAddress - Variable in class alluxio.master.service.rpc.RpcServerService
 
mBitsPerBucket - Variable in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
 
mBlockClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mBlockLocations - Variable in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
mBlocks - Variable in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
mBlockSize - Variable in class alluxio.stress.client.ClientIOParameters
 
mBlockSize - Variable in class alluxio.underfs.UfsFileStatus
 
mBucketName - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Bucket name of the object storage bucket.
mBucketName - Variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
Bucket name of the object storage bucket.
mBucketName - Variable in class alluxio.underfs.ObjectPositionReader
Name of the bucket the object resides in.
mBucketName - Variable in class alluxio.underfs.s3a.S3AInputStream
Name of the bucket the object resides in.
mBuckets - Variable in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
 
mBuf - Variable in class alluxio.examples.Performance.Worker
 
mBuffer - Variable in class alluxio.network.protocol.databuffer.NioDataBuffer
 
mBufferSize - Variable in class alluxio.stress.client.ClientIOParameters
 
mBufferSize - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mBytesWritten - Variable in class alluxio.client.file.FileOutStream
The number of bytes written.
mCacheSize - Variable in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
mCatalystRequestTimeout - Variable in class alluxio.master.backup.AbstractBackupRole
 
mChannel - Variable in class alluxio.AbstractClient
Underlying channel to the target service.
mChannelErrorEvent - Variable in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
 
mChannels - Variable in class alluxio.fsmaster.FileSystemBase
 
mChannels - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
List of channels authenticated against this server.
mChannelUnavailableEvent - Variable in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
 
mCheckpointsDir - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mCheckSync - Variable in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
mCleanupIntervalMs - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Interval for clean-up task to fire.
mClient - Variable in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
mClient - Variable in class alluxio.cli.fs.command.job.JobAttempt
 
mClient - Variable in class alluxio.underfs.cos.COSPositionReader
Client for operations with COS.
mClient - Variable in class alluxio.underfs.gcs.GCSPositionReader
Client for operations with Aliyun OSS.
mClient - Variable in class alluxio.underfs.obs.OBSPositionReader
Client for operations with OBS.
mClient - Variable in class alluxio.underfs.oss.OSSPositionReader
Client for operations with Aliyun OSS.
mClient - Variable in class alluxio.underfs.s3a.S3AInputStream
Client for operations with s3.
mClient - Variable in class alluxio.underfs.s3a.S3ALowLevelOutputStream
The Amazon S3 client to interact with S3.
mClient - Variable in class alluxio.underfs.s3a.S3APositionReader
Client for operations with s3.
mClient - Variable in class alluxio.worker.block.BlockMasterClient
 
mClients - Variable in class alluxio.stress.client.ClientIOParameters
 
mClients - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mClientType - Variable in class alluxio.stress.common.FileSystemParameters
 
mClock - Variable in class alluxio.heartbeat.SleepingTimer
 
mClock - Variable in class alluxio.master.AbstractMaster
The clock to use for determining the time.
mClock - Variable in class alluxio.resource.DynamicResourcePool
 
mClosed - Variable in class alluxio.AbstractClient
Is true if this client was closed by the user.
mClosed - Variable in class alluxio.client.file.ufs.UfsBaseFileSystem
 
mClosed - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Has the stream been closed.
mClosed - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Flag to indicate this stream has been closed, to ensure close is only done once.
mClosed - Variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
Flag to indicate this stream has been closed, to ensure close is only done once.
mCloser - Variable in class alluxio.cli.AbstractShell
 
mCloser - Variable in class alluxio.underfs.AbstractUfsManager
 
mCluster - Variable in class alluxio.stress.BaseParameters
 
mClusterAvgSpeedMbps - Variable in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
mClusterLimit - Variable in class alluxio.stress.BaseParameters
 
mClusterStartDelay - Variable in class alluxio.stress.BaseParameters
 
mCode - Variable in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
mCommands - Variable in class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
 
mCommandsAlt - Variable in class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
 
mConf - Variable in class alluxio.cli.command.AbstractFuseShellCommand
 
mConf - Variable in class alluxio.cli.hdfs.HdfsConfValidationTask
 
mConf - Variable in class alluxio.security.user.BaseUserState
 
mConf - Variable in class alluxio.stress.client.ClientIOParameters
 
mConf - Variable in class alluxio.stress.worker.UfsIOParameters
 
mConf - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mConf - Variable in class alluxio.worker.dora.PagedDoraWorker
 
mConfAddress - Variable in class alluxio.AbstractJobMasterClient
Address to load configuration, which may differ from mAddress.
mConfiguration - Variable in class alluxio.cli.AbstractShell
 
mConfiguration - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Alluxio client configuration.
mConnected - Variable in class alluxio.AbstractClient
Is true if this client is currently connected.
mContentHash - Variable in class alluxio.underfs.UfsFileStatus
 
mContentLength - Variable in class alluxio.underfs.UfsFileStatus
 
mContext - Variable in class alluxio.AbstractClient
Context of the client.
mContext - Variable in class alluxio.master.AlluxioMasterProcess
Master context.
mContext - Variable in class alluxio.master.MasterClientContextBuilder
 
mCount - Variable in class alluxio.stress.worker.WorkerBenchDataPoint
 
mCreationTimeMs - Variable in class alluxio.master.file.meta.MutableInode
 
mCurrentCapacity - Variable in class alluxio.resource.ResourcePool
It represents the total number of resources that have been created by this pool.
mData - Variable in class alluxio.stress.graph.Graph
 
mDataAvailableEvent - Variable in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
 
mDataSize - Variable in class alluxio.stress.worker.UfsIOParameters
 
mDataSizeBytes - Variable in class alluxio.stress.worker.IOTaskResult.Point
 
mDefaultAcl - Variable in class alluxio.master.file.contexts.CreateDirectoryContext
 
mDelay - Variable in class alluxio.RpcUtilsBench.BenchParams
 
mDelegatedFileSystem - Variable in class alluxio.client.file.DelegatingFileSystem
 
mDepth - Variable in class alluxio.fsmaster.FileSystemMasterBench.FileSystem
 
mDepth - Variable in class alluxio.inode.InodeBenchRead.Db
 
mDepth - Variable in class alluxio.inode.InodeBenchWrite.Db
 
mDepth - Variable in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
mDepthGenerator - Variable in class alluxio.BaseFileStructure
 
mDirectory - Variable in class alluxio.master.file.meta.MutableInode
 
mDirs - Variable in class alluxio.client.file.cache.allocator.HashAllocator
 
mDirSync - Variable in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
mDirty - Variable in class alluxio.master.metastore.caching.Cache.Entry
 
mDistributed - Variable in class alluxio.stress.BaseParameters
 
mDistribution - Variable in class alluxio.dora.meta.DoraMetaBench.Db
 
mDistribution - Variable in class alluxio.fsmaster.FileSystemMasterBench.FileSystem
 
mDistribution - Variable in class alluxio.inode.InodeBenchRead.Db
 
mDistribution - Variable in class alluxio.inode.InodeBenchWrite.Db
 
mDistribution - Variable in class alluxio.inode.RocksBenchRead.Db
 
mDistribution - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mDuration - Variable in class alluxio.stress.client.ClientIOParameters
 
mDuration - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mDurationSeconds - Variable in class alluxio.stress.worker.IOTaskResult.Point
 
MECHANISM - Static variable in class alluxio.security.authentication.plain.PlainSaslServerProvider
 
MEDIUM_HDD - Static variable in class alluxio.Constants
 
MEDIUM_MEM - Static variable in class alluxio.Constants
 
MEDIUM_SSD - Static variable in class alluxio.Constants
 
MEDIUM_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveBlockRequest
 
MEDIUM_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
MEDIUM_TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
MEDIUM_TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
MEDIUM_TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
MEDIUM_TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
mediumType() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the medium type of the location.
MEDIUMTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockLocation
 
MEDIUMTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockStoreLocationProto
 
MEDIUMTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
MEDIUMTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
MEDIUMTYPE_FIELD_NUMBER - Static variable in class alluxio.proto.meta.Block.BlockLocation
 
MembershipManager - Interface in alluxio.membership
Interface for worker membership management module.
MembershipManager.Factory - Class in alluxio.membership
Factory class to get or create a MembershipManager.
MembershipManagerWorkerProvider - Class in alluxio.master.scheduler
MembershipManager backed WorkerProvider for Scheduler.
MembershipManagerWorkerProvider(MembershipManager, FileSystemContext) - Constructor for class alluxio.master.scheduler.MembershipManagerWorkerProvider
CTOR for MembershipManagerWorkerProvider.
MembershipType - Enum in alluxio.membership
MembershipManager type.
memoize(Supplier<T>) - Static method in class alluxio.util.CommonUtils
Memoize implementation for java.util.function.supplier.
memoryCopyPartition() - Method in class alluxio.examples.Performance.GeneralWorker
Copies a partition in memory.
MemoryPageStore - Class in alluxio.client.file.cache.store
The MemoryPageStore is an implementation of PageStore which stores all pages in memory.
MemoryPageStore(int) - Constructor for class alluxio.client.file.cache.store.MemoryPageStore
Constructor of MemoryPageStore.
MemoryPageStoreDir - Class in alluxio.client.file.cache.store
Represents the dir and file level metadata of the MemPageStore.
MemoryPageStoreDir(PageStoreOptions, MemoryPageStore, CacheEvictor) - Constructor for class alluxio.client.file.cache.store.MemoryPageStoreDir
Constructor of MemPageStoreDir.
mEnd - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mEndPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Position the current stream was open till (exclusive).
mEndTime - Variable in class alluxio.master.job.AbstractJob
 
mEntriesAdded - Variable in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Total number of inputs to be operated on across batches.
merge(Map<?, ?>, Source) - Method in class alluxio.conf.AlluxioProperties
Merges the current configuration properties with new properties.
merge(AlluxioProperties) - Method in class alluxio.conf.AlluxioProperties
Merges properties from another instance.
merge(Map<?, ?>, Source) - Static method in class alluxio.conf.Configuration
Merges the current configuration properties with new properties.
merge(Map<?, ?>, Source) - Method in class alluxio.conf.InstancedConfiguration
Merges map of properties into the current alluxio properties.
merge(AlluxioProperties) - Method in class alluxio.conf.InstancedConfiguration
Merges map of properties into the current alluxio properties.
merge(AclActions) - Method in class alluxio.security.authorization.AclActions
Merges the actions.
merge(ClientIOTaskResult.ThreadCountResult) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
Merges (updates) a result with this result.
merge(TaskResultStatistics) - Method in class alluxio.stress.common.TaskResultStatistics
Merges (updates) a task result statistics with this statistics.
merge(IOTaskResult) - Method in class alluxio.stress.worker.IOTaskResult
Merge another result into itself.
merge(WorkerBenchTaskResult) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
Merges (updates) a task result with this result.
mergeAccessAcl(Acl.AccessControlList) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
mergeAcl(PAcl) - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
mergeAcl(Acl.AccessControlList) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
mergeAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
mergeAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
mergeAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
mergeActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
mergeActiveSyncTxId(File.ActiveSyncTxIdEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
mergeAddMountPoint(File.AddMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
mergeAddQuorumServerRequest(AddQuorumServerRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
mergeAddress(NetAddress) - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
mergeAddress(WorkerNetAddress) - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
mergeAddress(WorkerNetAddress) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
mergeAddresses(NetAddress) - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
mergeAddSyncPoint(File.AddSyncPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
mergeAllOrNone(AllOrNoneSet) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
mergeAlluxioConfiguration(Configuration, AlluxioConfiguration) - Static method in class alluxio.hadoop.HadoopConfigurationUtils
Merges an AlluxioConfiguration into an hadoop Configuration.
mergeAsyncPersistOptions(ScheduleAsyncPersistencePOptions) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
mergeAsyncPersistRequest(File.AsyncPersistRequestEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
mergeBaseLayout(Layout) - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
mergeBinaryStats(BinaryColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
mergeBlock(Block) - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
mergeBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
mergeBlockInfo(BlockInfo) - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
mergeBlockInfo(BlockInfo) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
mergeBlockInfo(Block.BlockInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
mergeBlockLocation(BlockLocation) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
mergeBlockMasterInfo(BlockMasterInfo) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
mergeBooleanStats(BooleanColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
mergeBucketProperty(HiveBucketProperty) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
mergeBuildVersion(BuildVersion) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
mergeBuildVersion(BuildVersion) - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
mergeCancelTaskCommand(CancelTaskCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
mergeChunk(Chunk) - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
mergeChunk(Chunk) - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
mergeClusterInfo(Meta.ClusterInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
mergeCmdProgress(CmdProgress) - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
mergeCmdStatusBlock(CmdStatusBlock) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
mergeCommand(Command) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
mergeCommand(FileSystemCommand) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
mergeCommand(WriteRequestCommand) - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
mergeCommandOptions(FileSystemCommandOptions) - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
mergeCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
mergeCommonOptions(Cache.PPageStoreCommonOptions) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
mergeCompleteFile(File.CompleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
mergeConstraint(Constraint) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
mergeCopyJob(Job.CopyJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
mergeCreateComplete(List<Journal.JournalEntry>) - Static method in class alluxio.master.file.InodeSyncStream
Merge inode entry with subsequent update inode and update inode file entries.
mergeCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
mergeCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
mergeData(SnapshotData) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
mergeData(ColumnStatisticsData) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
mergeData(SnapshotData) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
mergeDateStats(DateColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
mergeDb(Database) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
mergeDecimalStats(DecimalColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
mergeDefaultAcl(PAcl) - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
mergeDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
mergeDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
mergeDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
mergeDeleteBlock(Block.DeleteBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
mergeDeleteFile(File.DeleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
mergeDeleteMountPoint(File.DeleteMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
mergeDoubleStats(DoubleColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
mergeEquatable(EquatableValueSet) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
mergeFile(File) - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
mergeFileInfo(FileInfo) - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
mergeFileInfo(FileInfo) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
mergeFileInfo(FileInfo) - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
mergeFileInfo(FileInfo) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
mergeFilter(Job.FileFilter) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
mergeFilter(Job.FileFilter) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
mergeFrom(Message) - Method in class alluxio.grpc.ActionInfo.Builder
 
mergeFrom(ActionInfo) - Method in class alluxio.grpc.ActionInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ActionInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
mergeFrom(AddPolicyPOptions) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
mergeFrom(AddPolicyPRequest) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
mergeFrom(AddPolicyPResponse) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
mergeFrom(AddQuorumServerRequest) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
mergeFrom(AsyncCacheRequest) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
mergeFrom(AsyncCacheResponse) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BackupPOptions.Builder
 
mergeFrom(BackupPOptions) - Method in class alluxio.grpc.BackupPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BackupPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BackupPRequest.Builder
 
mergeFrom(BackupPRequest) - Method in class alluxio.grpc.BackupPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BackupPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BackupPStatus.Builder
 
mergeFrom(BackupPStatus) - Method in class alluxio.grpc.BackupPStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BackupPStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
mergeFrom(BackupStatusPRequest) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.Block.Builder
 
mergeFrom(Block) - Method in class alluxio.grpc.Block.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.Block.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
mergeFrom(BlockHeartbeatPOptions) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
mergeFrom(BlockHeartbeatPRequest) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
mergeFrom(BlockHeartbeatPResponse) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockIdList.Builder
 
mergeFrom(BlockIdList) - Method in class alluxio.grpc.BlockIdList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockIdList.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockInfo.Builder
 
mergeFrom(BlockInfo) - Method in class alluxio.grpc.BlockInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockLocation.Builder
 
mergeFrom(BlockLocation) - Method in class alluxio.grpc.BlockLocation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockLocation.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
mergeFrom(BlockMasterInfo) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockStatus.Builder
 
mergeFrom(BlockStatus) - Method in class alluxio.grpc.BlockStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
mergeFrom(BlockStoreLocationProto) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.BuildVersion.Builder
 
mergeFrom(BuildVersion) - Method in class alluxio.grpc.BuildVersion.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.BuildVersion.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CacheRequest.Builder
 
mergeFrom(CacheRequest) - Method in class alluxio.grpc.CacheRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CacheRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CacheResponse.Builder
 
mergeFrom(CacheResponse) - Method in class alluxio.grpc.CacheResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CacheResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CancelPOptions.Builder
 
mergeFrom(CancelPOptions) - Method in class alluxio.grpc.CancelPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CancelPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CancelPRequest.Builder
 
mergeFrom(CancelPRequest) - Method in class alluxio.grpc.CancelPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CancelPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CancelPResponse.Builder
 
mergeFrom(CancelPResponse) - Method in class alluxio.grpc.CancelPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CancelPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
mergeFrom(CancelTaskCommand) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
mergeFrom(CheckAccessPOptions) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
mergeFrom(CheckAccessPRequest) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
mergeFrom(CheckAccessPResponse) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
mergeFrom(CheckConsistencyPOptions) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
mergeFrom(CheckConsistencyPRequest) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
mergeFrom(CheckConsistencyPResponse) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
mergeFrom(CheckpointPOptions) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
mergeFrom(CheckpointPResponse) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckRequest.Builder
 
mergeFrom(CheckRequest) - Method in class alluxio.grpc.CheckRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CheckResponse.Builder
 
mergeFrom(CheckResponse) - Method in class alluxio.grpc.CheckResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CheckResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.Chunk.Builder
 
mergeFrom(Chunk) - Method in class alluxio.grpc.Chunk.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.Chunk.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
mergeFrom(ClearMetricsPRequest) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
mergeFrom(ClearMetricsPResponse) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
mergeFrom(ClearMetricsRequest) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
mergeFrom(ClearMetricsResponse) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ClientMetrics.Builder
 
mergeFrom(ClientMetrics) - Method in class alluxio.grpc.ClientMetrics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ClientMetrics.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CmdProgress.Builder
 
mergeFrom(CmdProgress) - Method in class alluxio.grpc.CmdProgress.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CmdProgress.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
mergeFrom(CmdStatusBlock) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CmdSummary.Builder
 
mergeFrom(CmdSummary) - Method in class alluxio.grpc.CmdSummary.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CmdSummary.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.Command.Builder
 
mergeFrom(Command) - Method in class alluxio.grpc.Command.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.Command.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
mergeFrom(CommitBlockPOptions) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
mergeFrom(CommitBlockPRequest) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
mergeFrom(CommitBlockPResponse) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
mergeFrom(CompleteFilePOptions) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
mergeFrom(CompleteFilePRequest) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
mergeFrom(CompleteFilePResponse) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
mergeFrom(ConfigCheckReport) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ConfigProperties.Builder
 
mergeFrom(ConfigProperties) - Method in class alluxio.grpc.ConfigProperties.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ConfigProperties.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ConfigProperty.Builder
 
mergeFrom(ConfigProperty) - Method in class alluxio.grpc.ConfigProperty.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ConfigProperty.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
mergeFrom(CopyJobPOptions) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CopyRequest.Builder
 
mergeFrom(CopyRequest) - Method in class alluxio.grpc.CopyRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CopyRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CopyResponse.Builder
 
mergeFrom(CopyResponse) - Method in class alluxio.grpc.CopyResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CopyResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
mergeFrom(CreateDirectoryPOptions) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
mergeFrom(CreateDirectoryPRequest) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
mergeFrom(CreateDirectoryPResponse) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
mergeFrom(CreateFilePOptions) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
mergeFrom(CreateFilePRequest) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
mergeFrom(CreateFilePResponse) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
mergeFrom(DecommissionWorkerPOptions) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
mergeFrom(DecommissionWorkerPResponse) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.DeletePOptions.Builder
 
mergeFrom(DeletePOptions) - Method in class alluxio.grpc.DeletePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.DeletePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.DeletePRequest.Builder
 
mergeFrom(DeletePRequest) - Method in class alluxio.grpc.DeletePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.DeletePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.DeletePResponse.Builder
 
mergeFrom(DeletePResponse) - Method in class alluxio.grpc.DeletePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.DeletePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
mergeFrom(DownloadSnapshotPRequest) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
mergeFrom(DownloadSnapshotPResponse) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.ErrorInfo.Builder
 
mergeFrom(ErrorInfo) - Method in class alluxio.grpc.ErrorInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ErrorInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
mergeFrom(ExistsPOptions) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
mergeFrom(ExistsPRequest) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
mergeFrom(ExistsPResponse) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.File.Builder
 
mergeFrom(File) - Method in class alluxio.grpc.File.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.File.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
mergeFrom(FileBlockInfo) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileFailure.Builder
 
mergeFrom(FileFailure) - Method in class alluxio.grpc.FileFailure.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileFailure.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileInfo.Builder
 
mergeFrom(FileInfo) - Method in class alluxio.grpc.FileInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
mergeFrom(FileSystemCommand) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
mergeFrom(FileSystemCommandOptions) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
mergeFrom(FileSystemHeartbeatPOptions) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
mergeFrom(FileSystemHeartbeatPRequest) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
mergeFrom(FileSystemHeartbeatPResponse) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
mergeFrom(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FreePOptions.Builder
 
mergeFrom(FreePOptions) - Method in class alluxio.grpc.FreePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FreePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FreePRequest.Builder
 
mergeFrom(FreePRequest) - Method in class alluxio.grpc.FreePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FreePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FreePResponse.Builder
 
mergeFrom(FreePResponse) - Method in class alluxio.grpc.FreePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FreePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
mergeFrom(FreeWorkerRequest) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
mergeFrom(FreeWorkerResponse) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.FsOpPId.Builder
 
mergeFrom(FsOpPId) - Method in class alluxio.grpc.FsOpPId.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.FsOpPId.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
mergeFrom(GetActionInfoOptions) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
mergeFrom(GetActionInfoRequest) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
mergeFrom(GetActionInfoResponse) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
mergeFrom(GetAllMasterStatusPOptions) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
mergeFrom(GetAllMasterStatusPRequest) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
mergeFrom(GetAllMasterStatusPResponse) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
mergeFrom(GetAllWorkerHealthPOptions) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
mergeFrom(GetAllWorkerHealthPRequest) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
mergeFrom(GetAllWorkerHealthPResponse) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
mergeFrom(GetBlockInfoPOptions) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
mergeFrom(GetBlockInfoPRequest) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
mergeFrom(GetBlockInfoPResponse) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
mergeFrom(GetBlockMasterInfoPOptions) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
mergeFrom(GetBlockMasterInfoPResponse) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
mergeFrom(GetCapacityBytesPOptions) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
mergeFrom(GetCapacityBytesPResponse) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
mergeFrom(GetCmdStatusDetailedOptions) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
mergeFrom(GetCmdStatusDetailedRequest) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
mergeFrom(GetCmdStatusDetailedResponse) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
mergeFrom(GetCmdStatusOptions) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
mergeFrom(GetCmdStatusRequest) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
mergeFrom(GetCmdStatusResponse) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
mergeFrom(GetConfigHashPOptions) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
mergeFrom(GetConfigHashPResponse) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
mergeFrom(GetConfigReportPOptions) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
mergeFrom(GetConfigReportPResponse) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
mergeFrom(GetConfigurationPOptions) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
mergeFrom(GetConfigurationPResponse) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
mergeFrom(GetFileInfoPOptions) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
mergeFrom(GetFileInfoPRequest) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
mergeFrom(GetFileInfoPResponse) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
mergeFrom(GetFilePathPRequest) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
mergeFrom(GetFilePathPResponse) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
mergeFrom(GetJobMasterIdPOptions) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
mergeFrom(GetJobMasterIdPRequest) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
mergeFrom(GetJobMasterIdPResponse) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
mergeFrom(GetJobProgressPRequest) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
mergeFrom(GetJobProgressPResponse) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
mergeFrom(GetJobServiceSummaryPOptions) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
mergeFrom(GetJobServiceSummaryPRequest) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
mergeFrom(GetJobServiceSummaryPResponse) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
mergeFrom(GetJobStatusDetailedPOptions) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
mergeFrom(GetJobStatusDetailedPRequest) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
mergeFrom(GetJobStatusDetailedPResponse) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
mergeFrom(GetJobStatusPOptions) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
mergeFrom(GetJobStatusPRequest) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
mergeFrom(GetJobStatusPResponse) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
mergeFrom(GetMasterIdPOptions) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
mergeFrom(GetMasterIdPRequest) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
mergeFrom(GetMasterIdPResponse) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
mergeFrom(GetMasterInfoPOptions) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
mergeFrom(GetMasterInfoPResponse) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
mergeFrom(GetMetricsPOptions) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
mergeFrom(GetMetricsPResponse) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
mergeFrom(GetMountIdPRequest) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
mergeFrom(GetMountIdPResponse) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
mergeFrom(GetMountTablePRequest) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
mergeFrom(GetMountTablePResponse) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
mergeFrom(GetNewBlockIdForFilePOptions) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
mergeFrom(GetNewBlockIdForFilePRequest) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
mergeFrom(GetNewBlockIdForFilePResponse) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
mergeFrom(GetNodeStatePRequest) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
mergeFrom(GetNodeStatePResponse) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
mergeFrom(GetPinnedFileIdsPOptions) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
mergeFrom(GetPinnedFileIdsPRequest) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
mergeFrom(GetPinnedFileIdsPResponse) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
mergeFrom(GetPolicyStatusPOptions) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
mergeFrom(GetPolicyStatusPRequest) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
mergeFrom(GetPolicyStatusPResponse) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
mergeFrom(GetQuorumInfoPOptions) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
mergeFrom(GetQuorumInfoPRequest) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
mergeFrom(GetQuorumInfoPResponse) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
mergeFrom(GetRegisterLeasePOptions) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
mergeFrom(GetRegisterLeasePRequest) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
mergeFrom(GetRegisterLeasePResponse) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
mergeFrom(GetServiceVersionPRequest) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
mergeFrom(GetServiceVersionPResponse) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
mergeFrom(GetSnapshotInfoRequest) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
mergeFrom(GetSnapshotInfoResponse) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
mergeFrom(GetSnapshotRequest) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
mergeFrom(GetStateLockHoldersPOptions) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
mergeFrom(GetStateLockHoldersPRequest) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
mergeFrom(GetStateLockHoldersPResponse) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
mergeFrom(GetStatusPOptions) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
mergeFrom(GetStatusPRequest) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
mergeFrom(GetStatusPResponse) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
mergeFrom(GetTransferLeaderMessageOptions) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
mergeFrom(GetTransferLeaderMessagePRequest) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
mergeFrom(GetTransferLeaderMessagePResponse) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
mergeFrom(GetUfsInfoPOptions) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
mergeFrom(GetUfsInfoPRequest) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
mergeFrom(GetUfsInfoPResponse) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
mergeFrom(GetUsedBytesPOptions) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
mergeFrom(GetUsedBytesPResponse) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
mergeFrom(GetWorkerIdPOptions) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
mergeFrom(GetWorkerIdPRequest) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
mergeFrom(GetWorkerIdPResponse) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
mergeFrom(GetWorkerInfoListPOptions) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
mergeFrom(GetWorkerInfoListPResponse) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
mergeFrom(GetWorkerLostStoragePOptions) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
mergeFrom(GetWorkerLostStoragePResponse) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
mergeFrom(GetWorkerReportPOptions) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
mergeFrom(InconsistentProperties) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
mergeFrom(InconsistentProperty) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
mergeFrom(InconsistentPropertyValues) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobCommand.Builder
 
mergeFrom(JobCommand) - Method in class alluxio.grpc.JobCommand.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobCommand.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobDescription.Builder
 
mergeFrom(JobDescription) - Method in class alluxio.grpc.JobDescription.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobDescription.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
mergeFrom(JobHeartbeatPOptions) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
mergeFrom(JobHeartbeatPRequest) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
mergeFrom(JobHeartbeatPResponse) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobInfo.Builder
 
mergeFrom(JobInfo) - Method in class alluxio.grpc.JobInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
mergeFrom(JobMasterHeartbeatPOptions) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
mergeFrom(JobMasterHeartbeatPRequest) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
mergeFrom(JobMasterHeartbeatPResponse) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
mergeFrom(JobMasterStatus) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobProgress.Builder
 
mergeFrom(JobProgress) - Method in class alluxio.grpc.JobProgress.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobProgress.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
mergeFrom(JobProgressPOptions) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
mergeFrom(JobServiceSummary) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
mergeFrom(JobStatusBlock) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobUnused.Builder
 
mergeFrom(JobUnused) - Method in class alluxio.grpc.JobUnused.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobUnused.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
mergeFrom(JobWorkerHealth) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
mergeFrom(JournalQueryRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
mergeFrom(JournalQueryResponse) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
mergeFrom(LatestSnapshotInfoPRequest) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
mergeFrom(ListAllPOptions) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
mergeFrom(ListAllPRequest) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
mergeFrom(ListAllPResponse) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
mergeFrom(ListPolicyPOptions) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
mergeFrom(ListPolicyPRequest) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
mergeFrom(ListPolicyPResponse) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
mergeFrom(ListProxyStatusPOptions) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
mergeFrom(ListProxyStatusPRequest) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
mergeFrom(ListProxyStatusPResponse) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
mergeFrom(ListStatusPartialPOptions) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
mergeFrom(ListStatusPartialPRequest) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
mergeFrom(ListStatusPartialPResponse) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
mergeFrom(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
mergeFrom(ListStatusPRequest) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
mergeFrom(ListStatusPResponse) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
mergeFrom(LoadFileFailure) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
mergeFrom(LoadFileRequest) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
mergeFrom(LoadFileResponse) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
mergeFrom(LoadJobPOptions) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
mergeFrom(LoadMetadataPOptions) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LoadRequest.Builder
 
mergeFrom(LoadRequest) - Method in class alluxio.grpc.LoadRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LoadRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LoadResponse.Builder
 
mergeFrom(LoadResponse) - Method in class alluxio.grpc.LoadResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LoadResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
mergeFrom(LocationBlockIdListEntry) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
mergeFrom(MasterHeartbeatPOptions) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
mergeFrom(MasterHeartbeatPRequest) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
mergeFrom(MasterHeartbeatPResponse) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MasterInfo.Builder
 
mergeFrom(MasterInfo) - Method in class alluxio.grpc.MasterInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MasterInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MasterVersion.Builder
 
mergeFrom(MasterVersion) - Method in class alluxio.grpc.MasterVersion.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MasterVersion.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
mergeFrom(MessagingRequestHeader) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
mergeFrom(MessagingResponseHeader) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.Metric.Builder
 
mergeFrom(Metric) - Method in class alluxio.grpc.Metric.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.Metric.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
mergeFrom(MetricsHeartbeatPOptions) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
mergeFrom(MetricsHeartbeatPRequest) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
mergeFrom(MetricsHeartbeatPResponse) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MetricValue.Builder
 
mergeFrom(MetricValue) - Method in class alluxio.grpc.MetricValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MetricValue.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MountPointInfo.Builder
 
mergeFrom(MountPointInfo) - Method in class alluxio.grpc.MountPointInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MountPointInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MountPOptions.Builder
 
mergeFrom(MountPOptions) - Method in class alluxio.grpc.MountPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MountPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MountPRequest.Builder
 
mergeFrom(MountPRequest) - Method in class alluxio.grpc.MountPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MountPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MountPResponse.Builder
 
mergeFrom(MountPResponse) - Method in class alluxio.grpc.MountPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MountPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
mergeFrom(MoveBlockRequest) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
mergeFrom(MoveBlockResponse) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
mergeFrom(MoveJobPOptions) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MoveRequest.Builder
 
mergeFrom(MoveRequest) - Method in class alluxio.grpc.MoveRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MoveRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.MoveResponse.Builder
 
mergeFrom(MoveResponse) - Method in class alluxio.grpc.MoveResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.MoveResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
mergeFrom(NeedsSyncRequest) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
mergeFrom(NeedsSyncResponse) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.NetAddress.Builder
 
mergeFrom(NetAddress) - Method in class alluxio.grpc.NetAddress.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.NetAddress.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
mergeFrom(NotifyWorkerIdPOptions) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
mergeFrom(NotifyWorkerIdPRequest) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
mergeFrom(NotifyWorkerIdPResponse) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
mergeFrom(OpenFilePOptions) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.PAcl.Builder
 
mergeFrom(PAcl) - Method in class alluxio.grpc.PAcl.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.PAcl.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.PAclEntry.Builder
 
mergeFrom(PAclEntry) - Method in class alluxio.grpc.PAclEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.PAclEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
mergeFrom(PersistCommandOptions) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.PersistFile.Builder
 
mergeFrom(PersistFile) - Method in class alluxio.grpc.PersistFile.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.PersistFile.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.PMode.Builder
 
mergeFrom(PMode) - Method in class alluxio.grpc.PMode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.PMode.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.PolicyInfo.Builder
 
mergeFrom(PolicyInfo) - Method in class alluxio.grpc.PolicyInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.PolicyInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.PolicyStatus.Builder
 
mergeFrom(PolicyStatus) - Method in class alluxio.grpc.PolicyStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.PolicyStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
mergeFrom(ProxyHeartbeatPOptions) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
mergeFrom(ProxyHeartbeatPRequest) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
mergeFrom(ProxyHeartbeatPResponse) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ProxyStatus.Builder
 
mergeFrom(ProxyStatus) - Method in class alluxio.grpc.ProxyStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ProxyStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
mergeFrom(QuorumServerInfo) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ReadRequest.Builder
 
mergeFrom(ReadRequest) - Method in class alluxio.grpc.ReadRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ReadRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ReadResponse.Builder
 
mergeFrom(ReadResponse) - Method in class alluxio.grpc.ReadResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ReadResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterCommand.Builder
 
mergeFrom(RegisterCommand) - Method in class alluxio.grpc.RegisterCommand.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterCommand.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
mergeFrom(RegisterJobMasterPOptions) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
mergeFrom(RegisterJobMasterPRequest) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
mergeFrom(RegisterJobMasterPResponse) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
mergeFrom(RegisterJobWorkerPOptions) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
mergeFrom(RegisterJobWorkerPRequest) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
mergeFrom(RegisterJobWorkerPResponse) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
mergeFrom(RegisterMasterPOptions) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
mergeFrom(RegisterMasterPRequest) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
mergeFrom(RegisterMasterPResponse) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
mergeFrom(RegisterWorkerPOptions) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
mergeFrom(RegisterWorkerPRequest) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
mergeFrom(RegisterWorkerPResponse) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
mergeFrom(RemoveBlockRequest) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
mergeFrom(RemoveBlockResponse) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
mergeFrom(RemoveDisabledWorkerPOptions) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
mergeFrom(RemoveDisabledWorkerPResponse) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
mergeFrom(RemovePathConfigurationPOptions) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
mergeFrom(RemovePathConfigurationPRequest) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
mergeFrom(RemovePathConfigurationPResponse) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
mergeFrom(RemovePolicyPOptions) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
mergeFrom(RemovePolicyPRequest) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
mergeFrom(RemovePolicyPResponse) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
mergeFrom(RemoveQuorumServerPOptions) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
mergeFrom(RemoveQuorumServerPRequest) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
mergeFrom(RemoveQuorumServerPResponse) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RenamePOptions.Builder
 
mergeFrom(RenamePOptions) - Method in class alluxio.grpc.RenamePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RenamePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RenamePRequest.Builder
 
mergeFrom(RenamePRequest) - Method in class alluxio.grpc.RenamePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RenamePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RenamePResponse.Builder
 
mergeFrom(RenamePResponse) - Method in class alluxio.grpc.RenamePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RenamePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
mergeFrom(ResetPrioritiesPOptions) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
mergeFrom(ResetPrioritiesPRequest) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
mergeFrom(ResetPrioritiesPResponse) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RetryInfo.Builder
 
mergeFrom(RetryInfo) - Method in class alluxio.grpc.RetryInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RetryInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
mergeFrom(ReverseResolvePRequest) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
mergeFrom(ReverseResolvePResponse) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.Route.Builder
 
mergeFrom(Route) - Method in class alluxio.grpc.Route.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.Route.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RouteFailure.Builder
 
mergeFrom(RouteFailure) - Method in class alluxio.grpc.RouteFailure.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RouteFailure.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RunPOptions.Builder
 
mergeFrom(RunPOptions) - Method in class alluxio.grpc.RunPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RunPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RunPRequest.Builder
 
mergeFrom(RunPRequest) - Method in class alluxio.grpc.RunPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RunPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RunPResponse.Builder
 
mergeFrom(RunPResponse) - Method in class alluxio.grpc.RunPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RunPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
mergeFrom(RunTaskCommand) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
mergeFrom(S3SyntaxOptions) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SaslMessage.Builder
 
mergeFrom(SaslMessage) - Method in class alluxio.grpc.SaslMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SaslMessage.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
mergeFrom(ScheduleAsyncPersistencePOptions) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
mergeFrom(ScheduleAsyncPersistencePRequest) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
mergeFrom(ScheduleAsyncPersistencePResponse) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
mergeFrom(SetAclPOptions) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
mergeFrom(SetAclPRequest) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
mergeFrom(SetAclPResponse) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
mergeFrom(SetAttributePOptions) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
mergeFrom(SetAttributePRequest) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
mergeFrom(SetAttributePResponse) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
mergeFrom(SetPathConfigurationPOptions) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
mergeFrom(SetPathConfigurationPRequest) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
mergeFrom(SetPathConfigurationPResponse) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
mergeFrom(SetTaskPoolSizeCommand) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SnapshotData.Builder
 
mergeFrom(SnapshotData) - Method in class alluxio.grpc.SnapshotData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SnapshotData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
mergeFrom(SnapshotMetadata) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StatusSummary.Builder
 
mergeFrom(StatusSummary) - Method in class alluxio.grpc.StatusSummary.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StatusSummary.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
mergeFrom(StopJobPRequest) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
mergeFrom(StopJobPResponse) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.StorageList.Builder
 
mergeFrom(StorageList) - Method in class alluxio.grpc.StorageList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.StorageList.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
mergeFrom(SubmitJobPRequest) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
mergeFrom(SubmitJobPResponse) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SubmitOptions.Builder
 
mergeFrom(SubmitOptions) - Method in class alluxio.grpc.SubmitOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SubmitOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SubmitRequest.Builder
 
mergeFrom(SubmitRequest) - Method in class alluxio.grpc.SubmitRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SubmitRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.SubmitResponse.Builder
 
mergeFrom(SubmitResponse) - Method in class alluxio.grpc.SubmitResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.SubmitResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
mergeFrom(AllOrNoneSet) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
mergeFrom(AttachDatabasePRequest) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
mergeFrom(AttachDatabasePResponse) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
mergeFrom(BinaryColumnStatsData) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
mergeFrom(BooleanColumnStatsData) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
mergeFrom(ColumnStatisticsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
mergeFrom(ColumnStatisticsInfo) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
mergeFrom(ColumnStatisticsList) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Constraint.Builder
 
mergeFrom(Constraint) - Method in class alluxio.grpc.table.Constraint.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Constraint.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Database.Builder
 
mergeFrom(Database) - Method in class alluxio.grpc.table.Database.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Database.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Date.Builder
 
mergeFrom(Date) - Method in class alluxio.grpc.table.Date.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Date.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
mergeFrom(DateColumnStatsData) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Decimal.Builder
 
mergeFrom(Decimal) - Method in class alluxio.grpc.table.Decimal.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Decimal.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
mergeFrom(DecimalColumnStatsData) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
mergeFrom(DetachDatabasePRequest) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
mergeFrom(DetachDatabasePResponse) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Domain.Builder
 
mergeFrom(Domain) - Method in class alluxio.grpc.table.Domain.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Domain.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
mergeFrom(DoubleColumnStatsData) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
mergeFrom(EquatableValueSet) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
mergeFrom(FieldSchema) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
mergeFrom(FileStatistics) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
mergeFrom(GetAllDatabasesPRequest) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
mergeFrom(GetAllDatabasesPResponse) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
mergeFrom(GetAllTablesPRequest) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
mergeFrom(GetAllTablesPResponse) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
mergeFrom(GetDatabasePRequest) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
mergeFrom(GetDatabasePResponse) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
mergeFrom(GetPartitionColumnStatisticsPRequest) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
mergeFrom(GetPartitionColumnStatisticsPResponse) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
mergeFrom(GetTableColumnStatisticsPRequest) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
mergeFrom(GetTableColumnStatisticsPResponse) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
mergeFrom(GetTablePRequest) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
mergeFrom(GetTablePResponse) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
mergeFrom(GetTransformJobInfoPRequest) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
mergeFrom(GetTransformJobInfoPResponse) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Layout.Builder
 
mergeFrom(Layout) - Method in class alluxio.grpc.table.Layout.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Layout.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
mergeFrom(HiveBucketProperty) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
mergeFrom(PartitionInfo) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
mergeFrom(SortingColumn) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
mergeFrom(Storage) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
mergeFrom(StorageFormat) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
mergeFrom(LayoutSpec) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
mergeFrom(LongColumnStatsData) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Partition.Builder
 
mergeFrom(Partition) - Method in class alluxio.grpc.table.Partition.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Partition.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
mergeFrom(PartitionSpec) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Range.Builder
 
mergeFrom(Range) - Method in class alluxio.grpc.table.Range.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Range.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.RangeSet.Builder
 
mergeFrom(RangeSet) - Method in class alluxio.grpc.table.RangeSet.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.RangeSet.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
mergeFrom(ReadTablePRequest) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
mergeFrom(ReadTablePResponse) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Schema.Builder
 
mergeFrom(Schema) - Method in class alluxio.grpc.table.Schema.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Schema.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
mergeFrom(StringColumnStatsData) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
mergeFrom(SyncDatabasePRequest) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
mergeFrom(SyncDatabasePResponse) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
mergeFrom(SyncStatus) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.TableInfo.Builder
 
mergeFrom(TableInfo) - Method in class alluxio.grpc.table.TableInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.TableInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Transformation.Builder
 
mergeFrom(Transformation) - Method in class alluxio.grpc.table.Transformation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Transformation.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
mergeFrom(TransformJobInfo) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
mergeFrom(TransformTablePRequest) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
mergeFrom(TransformTablePResponse) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.table.Value.Builder
 
mergeFrom(Value) - Method in class alluxio.grpc.table.Value.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.table.Value.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TierList.Builder
 
mergeFrom(TierList) - Method in class alluxio.grpc.TierList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TierList.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
mergeFrom(TransferLeaderMessage) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
mergeFrom(TransferLeadershipPOptions) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
mergeFrom(TransferLeadershipPRequest) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
mergeFrom(TransferLeadershipPResponse) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TransportMessage.Builder
 
mergeFrom(TransportMessage) - Method in class alluxio.grpc.TransportMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TransportMessage.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
mergeFrom(TriggerPolicyRequest) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
mergeFrom(TriggerPolicyResponse) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
mergeFrom(UfsFileStatus) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UfsInfo.Builder
 
mergeFrom(UfsInfo) - Method in class alluxio.grpc.UfsInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UfsInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
mergeFrom(UfsReadOptions) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UfsStatus.Builder
 
mergeFrom(UfsStatus) - Method in class alluxio.grpc.UfsStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UfsStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
mergeFrom(UnmountPOptions) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
mergeFrom(UnmountPRequest) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
mergeFrom(UnmountPResponse) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
mergeFrom(UpdateConfigurationPRequest) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
mergeFrom(UpdateConfigurationPResponse) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
mergeFrom(UpdateMountPRequest) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
mergeFrom(UpdateMountPResponse) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
mergeFrom(UpdateUfsModePOptions) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
mergeFrom(UpdateUfsModePRequest) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
mergeFrom(UpdateUfsModePResponse) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
mergeFrom(UploadSnapshotPRequest) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
mergeFrom(UploadSnapshotPResponse) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
mergeFrom(Message) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
mergeFrom(WorkerIdentity) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.WorkerInfo.Builder
 
mergeFrom(WorkerInfo) - Method in class alluxio.grpc.WorkerInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WorkerInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
mergeFrom(WorkerLostStorageInfo) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
mergeFrom(WorkerNetAddress) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.WriteOptions.Builder
 
mergeFrom(WriteOptions) - Method in class alluxio.grpc.WriteOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WriteOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.WriteRequest.Builder
 
mergeFrom(WriteRequest) - Method in class alluxio.grpc.WriteRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WriteRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
mergeFrom(WriteRequestCommand) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
mergeFrom(Message) - Method in class alluxio.grpc.WriteResponse.Builder
 
mergeFrom(WriteResponse) - Method in class alluxio.grpc.WriteResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.grpc.WriteResponse.Builder
 
mergeFrom(CheckAccessPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckAccessContext
Merges and embeds the given CheckAccessPOptions with the corresponding master options.
mergeFrom(CheckConsistencyPOptions.Builder) - Static method in class alluxio.master.file.contexts.CheckConsistencyContext
Merges and embeds the given CheckConsistencyPOptions with the corresponding master options.
mergeFrom(CompleteFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CompleteFileContext
Merges and embeds the given CompleteFilePOptions with the corresponding master options.
mergeFrom(CreateDirectoryPOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateDirectoryContext
Merges and embeds the given CreateDirectoryPOptions with the corresponding master options.
mergeFrom(CreateFilePOptions.Builder) - Static method in class alluxio.master.file.contexts.CreateFileContext
Merges and embeds the given CreateFilePOptions with the corresponding master options.
mergeFrom(DeletePOptions.Builder) - Static method in class alluxio.master.file.contexts.DeleteContext
Merges and embeds the given DeletePOptions with the corresponding master options.
mergeFrom(ExistsPOptions.Builder) - Static method in class alluxio.master.file.contexts.ExistsContext
Merges and embeds the given ExistsPOptions with the corresponding master options.
mergeFrom(FreePOptions.Builder) - Static method in class alluxio.master.file.contexts.FreeContext
Merges and embeds the given FreePOptions with the corresponding master options.
mergeFrom(GetStatusPOptions.Builder) - Static method in class alluxio.master.file.contexts.GetStatusContext
Merges and embeds the given GetStatusPOptions with the corresponding master options.
mergeFrom(ListStatusPOptions.Builder) - Static method in class alluxio.master.file.contexts.ListStatusContext
Merges and embeds the given ListStatusPOptions with the corresponding master options.
mergeFrom(ListStatusPartialPOptions.Builder) - Static method in class alluxio.master.file.contexts.ListStatusContext
Merges and embeds the given ListStatusPartialPOptions with the corresponding master options.
mergeFrom(LoadMetadataPOptions.Builder) - Static method in class alluxio.master.file.contexts.LoadMetadataContext
Merges and embeds the given LoadMetadataPOptions with the corresponding master options.
mergeFrom(MountPOptions.Builder) - Static method in class alluxio.master.file.contexts.MountContext
Merges and embeds the given MountPOptions with the corresponding master options.
mergeFrom(RenamePOptions.Builder) - Static method in class alluxio.master.file.contexts.RenameContext
Merges and embeds the given RenamePOptions with the corresponding master options.
mergeFrom(ScheduleAsyncPersistencePOptions.Builder) - Static method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
Merges and embeds the given ScheduleAsyncPersistencePOptions with the corresponding master options.
mergeFrom(SetAclPOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAclContext
Merges and embeds the given SetAclPOptions with the corresponding master options.
mergeFrom(SetAttributePOptions.Builder) - Static method in class alluxio.master.file.contexts.SetAttributeContext
Merges and embeds the given SetAttributePOptions with the corresponding master options.
mergeFrom(Message) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
mergeFrom(Cache.PPageStoreCommonOptions) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
mergeFrom(Cache.PRocksPageStoreOptions) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
mergeFrom(Protocol.AsyncCacheRequest) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeFrom(Protocol.CreateUfsFileOptions) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
mergeFrom(Protocol.Heartbeat) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
mergeFrom(Protocol.LocalBlockCloseRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
mergeFrom(Protocol.LocalBlockCompleteRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
mergeFrom(Protocol.LocalBlockCreateRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
mergeFrom(Protocol.LocalBlockCreateResponse) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
mergeFrom(Protocol.LocalBlockOpenRequest) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
mergeFrom(Protocol.LocalBlockOpenResponse) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeFrom(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
mergeFrom(Protocol.ReadRequest) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
mergeFrom(Protocol.ReadResponse) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
mergeFrom(Protocol.Response) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
mergeFrom(Protocol.WriteRequest) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
mergeFrom(Block.BlockContainerIdGeneratorEntry) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
mergeFrom(Block.BlockInfoEntry) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
mergeFrom(Block.DeleteBlockEntry) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
mergeFrom(File.ActiveSyncTxIdEntry) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
mergeFrom(File.AddMountPointEntry) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
mergeFrom(File.AddSyncPointEntry) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
mergeFrom(File.AsyncPersistRequestEntry) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
mergeFrom(File.CompleteFileEntry) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
mergeFrom(File.DeleteFileEntry) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
mergeFrom(File.DeleteMountPointEntry) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
mergeFrom(File.InodeDirectoryEntry) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
mergeFrom(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
mergeFrom(File.InodeFileEntry) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
mergeFrom(File.InodeLastModificationTimeEntry) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
mergeFrom(File.NewBlockEntry) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
mergeFrom(File.PersistDirectoryEntry) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
mergeFrom(File.PersistFileEntry) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
mergeFrom(File.RemoveSyncPointEntry) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
mergeFrom(File.RenameEntry) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
mergeFrom(File.SetAclEntry) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
mergeFrom(File.SetAttributeEntry) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
mergeFrom(File.StringPairEntry) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
mergeFrom(File.UpdateInodeDirectoryEntry) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
mergeFrom(File.UpdateInodeEntry) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
mergeFrom(File.UpdateInodeFileEntry) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
mergeFrom(File.UpdateUfsModeEntry) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
mergeFrom(Job.CopyJobEntry) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
mergeFrom(Job.FileFilter) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
mergeFrom(Job.LoadJobEntry) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
mergeFrom(Job.MoveJobEntry) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
mergeFrom(Journal.JournalEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
mergeFrom(Journal.JournalOpPId) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
mergeFrom(Meta.ClusterInfoEntry) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
mergeFrom(Meta.PathPropertiesEntry) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
mergeFrom(Meta.RemovePathPropertiesEntry) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
mergeFrom(Policy.PolicyDefinitionEntry) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
mergeFrom(Policy.PolicyRemoveEntry) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
mergeFrom(Block.BlockLocation) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
mergeFrom(Block.BlockMeta) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
mergeFrom(DoraMeta.FileStatus) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
mergeFrom(InodeMeta.Inode) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
mergeFrom(Acl.AccessControlList) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
mergeFrom(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
mergeFrom(Acl.AclEntry) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
mergeFrom(Message) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
mergeFrom(Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
mergeHigh(Value) - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
mergeHighValue(Date) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
mergeHighValue(Decimal) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
mergeInodeDirectory(File.InodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
mergeInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
mergeInodeFile(File.InodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
mergeInodeLastModificationTime(File.InodeLastModificationTimeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
mergeJobDescription(JobDescription) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
mergeJobDescription(JobDescription) - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
mergeJobInfo(JobInfo) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
mergeJobInfo(JobInfo) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
mergeJobWorkerHealth(JobWorkerHealth) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
MergeJournalContext - Class in alluxio.master.journal
Context for merging journal entries together for a wrapped journal context.
MergeJournalContext(JournalContext, AlluxioURI, UnaryOperator<List<Journal.JournalEntry>>) - Constructor for class alluxio.master.journal.MergeJournalContext
Constructs a MergeJournalContext.
mergeKey(BlockStoreLocationProto) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
mergeLatest(SnapshotMetadata) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
mergeLayout(Layout) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
mergeLayout(Layout) - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
mergeLayoutSpec(LayoutSpec) - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
mergeLoadJob(Job.LoadJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
mergeLongStats(LongColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
mergeLow(Value) - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
mergeLowValue(Date) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
mergeLowValue(Decimal) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
mergeMaskActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
mergeMasterAddress(NetAddress) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
mergeMasterAddress(NetAddress) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
mergeMasterAddress(NetAddress) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
mergeMasterInfo(MasterInfo) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
mergeMode(PMode) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
mergeMode(PMode) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
mergeMode(PMode) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
mergeMoveJob(Job.MoveJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
mergeNewBlock(File.NewBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
mergeOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
mergeOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
mergeOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
mergeOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
mergeOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
mergeOperationId(FsOpPId) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
mergeOperationId(Journal.JournalOpPId) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
mergeOptions(AddPolicyPOptions) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
mergeOptions(BackupPOptions) - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
mergeOptions(BlockHeartbeatPOptions) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
mergeOptions(CancelPOptions) - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
mergeOptions(CheckAccessPOptions) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
mergeOptions(CheckConsistencyPOptions) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
mergeOptions(CommitBlockPOptions) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
mergeOptions(CompleteFilePOptions) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
mergeOptions(CreateDirectoryPOptions) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
mergeOptions(CreateFilePOptions) - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
mergeOptions(DeletePOptions) - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
mergeOptions(ExistsPOptions) - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
mergeOptions(FileSystemHeartbeatPOptions) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
mergeOptions(FreePOptions) - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
mergeOptions(GetPolicyStatusPOptions) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
mergeOptions(GetAllMasterStatusPOptions) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
mergeOptions(GetAllWorkerHealthPOptions) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
mergeOptions(GetBlockInfoPOptions) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
mergeOptions(GetCmdStatusOptions) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
mergeOptions(GetCmdStatusOptions) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
mergeOptions(GetFileInfoPOptions) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
mergeOptions(GetJobMasterIdPOptions) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
mergeOptions(JobProgressPOptions) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
mergeOptions(GetJobServiceSummaryPOptions) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
mergeOptions(GetJobStatusDetailedPOptions) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
mergeOptions(GetJobStatusPOptions) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
mergeOptions(GetMasterIdPOptions) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
mergeOptions(GetNewBlockIdForFilePOptions) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
mergeOptions(GetPinnedFileIdsPOptions) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
mergeOptions(GetPolicyStatusPOptions) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
mergeOptions(GetQuorumInfoPOptions) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
mergeOptions(GetRegisterLeasePOptions) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
mergeOptions(GetStateLockHoldersPOptions) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
mergeOptions(GetStatusPOptions) - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
mergeOptions(GetUfsInfoPOptions) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
mergeOptions(GetWorkerIdPOptions) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
mergeOptions(JobHeartbeatPOptions) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
mergeOptions(JobMasterHeartbeatPOptions) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
mergeOptions(ListAllPOptions) - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
mergeOptions(ListPolicyPOptions) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
mergeOptions(ListProxyStatusPOptions) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
mergeOptions(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
mergeOptions(ListStatusPartialPOptions) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
mergeOptions(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
mergeOptions(UfsReadOptions) - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
mergeOptions(UfsReadOptions) - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
mergeOptions(MasterHeartbeatPOptions) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
mergeOptions(MetricsHeartbeatPOptions) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
mergeOptions(MountPOptions) - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
mergeOptions(NotifyWorkerIdPOptions) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
mergeOptions(AddPolicyPOptions) - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
mergeOptions(ProxyHeartbeatPOptions) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
mergeOptions(RegisterJobMasterPOptions) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
mergeOptions(RegisterJobWorkerPOptions) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
mergeOptions(RegisterMasterPOptions) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
mergeOptions(RegisterWorkerPOptions) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
mergeOptions(RemovePathConfigurationPOptions) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
mergeOptions(RemovePolicyPOptions) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
mergeOptions(RemoveQuorumServerPOptions) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
mergeOptions(RenamePOptions) - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
mergeOptions(ResetPrioritiesPOptions) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
mergeOptions(RunPOptions) - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
mergeOptions(ScheduleAsyncPersistencePOptions) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
mergeOptions(SetAclPOptions) - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
mergeOptions(SetAttributePOptions) - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
mergeOptions(SetPathConfigurationPOptions) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
mergeOptions(SubmitOptions) - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
mergeOptions(TransferLeadershipPOptions) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
mergeOptions(UnmountPOptions) - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
mergeOptions(MountPOptions) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
mergeOptions(UpdateUfsModePOptions) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
mergeOptions(AddPolicyPOptions) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
mergeOtherActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
mergePartitionSpec(PartitionSpec) - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
mergePathProperties(Meta.PathPropertiesEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
mergePersistDirectory(File.PersistDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
mergePersistOptions(PersistCommandOptions) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
mergePolicy(PolicyInfo) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
mergePolicyDefinition(Policy.PolicyDefinitionEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
mergePolicyRemove(Policy.PolicyRemoveEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
mergeProperties(MountPOptions) - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
mergeProxyAddress(NetAddress) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
mergeRange(RangeSet) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
mergeRegisterCommand(RegisterCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
mergeRemovePathProperties(Meta.RemovePathPropertiesEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
mergeRemoveSyncPoint(File.RemoveSyncPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
mergeRename(File.RenameEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
mergeReport(ConfigCheckReport) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
mergeRequestHeader(MessagingRequestHeader) - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
mergeResponseHeader(MessagingResponseHeader) - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
mergeRoute(Route) - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
mergeRunTaskCommand(RunTaskCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
mergeS3SyntaxOptions(S3SyntaxOptions) - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
mergeSchema(Schema) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
mergeServerAddress(NetAddress) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
mergeServerAddress(NetAddress) - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
mergeServerAddress(NetAddress) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
mergeServerAddress(NetAddress) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
mergeSetAcl(File.SetAclEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
mergeSetAttribute(File.SetAttributeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
mergeSetTaskPoolSizeCommand(SetTaskPoolSizeCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
mergeSnapshotInfo(SnapshotMetadata) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
mergeSnapshotInfoRequest(GetSnapshotInfoRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
mergeSnapshotInfoResponse(GetSnapshotInfoResponse) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
mergeSnapshotRequest(GetSnapshotRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
mergeStatus(PolicyStatus) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
mergeStatus(SyncStatus) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
mergeStorage(Storage) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
mergeStorageFormat(StorageFormat) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
mergeStringStats(StringColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
mergeSummary(JobServiceSummary) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
mergeSyncStatus(SyncStatus) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
mergeTableInfo(TableInfo) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
mergeTransMsg(TransferLeaderMessage) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
mergeUfsFileStatus(UfsFileStatus) - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
mergeUfsInfo(UfsInfo) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
mergeUfsReadOptions(UfsReadOptions) - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
mergeUfsReadOptions(UfsReadOptions) - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
mergeUfsReadWorkerLocation(WorkerNetAddress) - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
mergeUfsStatus(UfsStatus) - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ActionInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Block.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockIdList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockLocation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BuildVersion.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CacheRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CacheResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Chunk.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClientMetrics.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdProgress.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdSummary.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Command.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigProperties.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigProperty.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ErrorInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.File.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileFailure.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FsOpPId.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobCommand.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobDescription.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobProgress.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobUnused.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterVersion.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Metric.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricValue.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPointInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NetAddress.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PAcl.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PAclEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PersistFile.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PMode.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PolicyInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PolicyStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReadRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReadResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterCommand.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RetryInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Route.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RouteFailure.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SaslMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SnapshotData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StatusSummary.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StorageList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Constraint.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Database.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Date.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Decimal.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Domain.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Layout.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Partition.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Range.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.RangeSet.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Schema.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TableInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Transformation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Value.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TierList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransportMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
mergeUpdateInode(File.UpdateInodeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
mergeUpdateInodeDirectory(File.UpdateInodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
mergeUpdateInodeFile(File.UpdateInodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
mergeUpdateUfsMode(File.UpdateUfsModeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
mergeValue(BlockIdList) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
mergeVersion(BuildVersion) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
mergeVersion(BuildVersion) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
mergeVersion(BuildVersion) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
mergeVersion(BuildVersion) - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
mergeVersion(BuildVersion) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
mergeVersion(BuildVersion) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
mergeWorkerAddress(WorkerNetAddress) - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
mergeWorkerLocation(WorkerNetAddress) - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
mergeWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
mergeWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
mergeWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
mergeWriteOptions(WriteOptions) - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
mergeWriteOptions(WriteOptions) - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
mErrors - Variable in class alluxio.stress.graph.Graph
 
MESOS_LOCAL_INSTALL - Static variable in class alluxio.Constants
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockStatus
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileFailure
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileFailure
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.RouteFailure
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.TransportMessage
 
MESSAGE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.Response
 
MESSAGETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
 
MessagingRequestHeader - Class in alluxio.grpc
Protobuf type alluxio.grpc.messaging.MessagingRequestHeader
MessagingRequestHeader.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.messaging.MessagingRequestHeader
MessagingRequestHeaderOrBuilder - Interface in alluxio.grpc
 
MessagingResponseHeader - Class in alluxio.grpc
Protobuf type alluxio.grpc.messaging.MessagingResponseHeader
MessagingResponseHeader.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.messaging.MessagingResponseHeader
MessagingResponseHeaderOrBuilder - Interface in alluxio.grpc
 
MessagingServiceGrpc - Class in alluxio.grpc
The messaging transport service.
MessagingServiceGrpc.AsyncService - Interface in alluxio.grpc
The messaging transport service.
MessagingServiceGrpc.MessagingServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service MessagingService.
MessagingServiceGrpc.MessagingServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service MessagingService.
MessagingServiceGrpc.MessagingServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service MessagingService.
MessagingServiceGrpc.MessagingServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service MessagingService.
MessagingServiceImplBase() - Constructor for class alluxio.grpc.MessagingServiceGrpc.MessagingServiceImplBase
 
MessagingTransportProto - Class in alluxio.grpc
 
Meta - Class in alluxio.proto.journal
 
Meta.ClusterInfoEntry - Class in alluxio.proto.journal
next available id: 2
Meta.ClusterInfoEntry.Builder - Class in alluxio.proto.journal
next available id: 2
Meta.ClusterInfoEntryOrBuilder - Interface in alluxio.proto.journal
 
Meta.PathPropertiesEntry - Class in alluxio.proto.journal
next available id: 3
Meta.PathPropertiesEntry.Builder - Class in alluxio.proto.journal
next available id: 3
Meta.PathPropertiesEntryOrBuilder - Interface in alluxio.proto.journal
 
Meta.RemovePathPropertiesEntry - Class in alluxio.proto.journal
next available id: 2
Meta.RemovePathPropertiesEntry.Builder - Class in alluxio.proto.journal
next available id: 2
Meta.RemovePathPropertiesEntryOrBuilder - Interface in alluxio.proto.journal
 
META_MASTER_BACKUP_MESSAGING_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
META_MASTER_BACKUP_MESSAGING_SERVICE = 15;
META_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
META_MASTER_CLIENT_SERVICE = 7;
META_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_CONFIG_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_CONFIG_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
META_MASTER_CONFIG_SERVICE = 6;
META_MASTER_CONFIG_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_MASTER_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_MASTER_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
META_MASTER_MASTER_SERVICE = 8;
META_MASTER_MASTER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_NAME - Static variable in class alluxio.Constants
 
META_MASTER_PROXY_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_PROXY_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
META_MASTER_PROXY_SERVICE = 18;
META_MASTER_PROXY_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MetaCommand - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.meta.MetaCommand
MetaCommand_Nothing_VALUE - Static variable in enum alluxio.grpc.JobMasterMetaCommand
MetaCommand_Nothing = 1;
MetaCommand_Nothing_VALUE - Static variable in enum alluxio.grpc.MetaCommand
MetaCommand_Nothing = 1;
MetaCommand_Register_VALUE - Static variable in enum alluxio.grpc.JobMasterMetaCommand
Ask the standby master to re-register.
MetaCommand_Register_VALUE - Static variable in enum alluxio.grpc.MetaCommand
Ask the standby master to re-register.
MetaCommand_Unknown_VALUE - Static variable in enum alluxio.grpc.JobMasterMetaCommand
MetaCommand_Unknown = 0;
MetaCommand_Unknown_VALUE - Static variable in enum alluxio.grpc.MetaCommand
MetaCommand_Unknown = 0;
METADATA_CACHE_EXPIRE_TIME_OPTION_NAME - Static variable in class alluxio.fuse.options.MountOptions
 
METADATA_CACHE_SIZE_OPTION_NAME - Static variable in class alluxio.fuse.options.MountOptions
 
METADATA_SYNC_PREFETCH_CANCEL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
METADATA_SYNC_PREFETCH_FAIL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
METADATA_SYNC_PREFETCH_OPS_COUNT - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
METADATA_SYNC_PREFETCH_PATHS - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
METADATA_SYNC_PREFETCH_RETRIES - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
METADATA_SYNC_PREFETCH_SUCCESS - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
METADATA_TOO_LARGE - Static variable in class alluxio.s3.S3ErrorCode
 
METADATA_TOO_LARGE - Static variable in class alluxio.s3.S3ErrorCode.Name
 
MetadataCache - Class in alluxio.client.file
Cache for metadata of paths.
MetadataCache(int) - Constructor for class alluxio.client.file.MetadataCache
 
MetadataCache(int, long) - Constructor for class alluxio.client.file.MetadataCache
 
MetadataCacheCommand - Class in alluxio.cli.command
Gets information of or makes changes to the Fuse client metadata cache.
MetadataCacheCommand(FileSystem, AlluxioConfiguration) - Constructor for class alluxio.cli.command.MetadataCacheCommand
 
MetadataCachingFileSystem - Class in alluxio.client.file
FileSystem implementation with the capability of caching metadata of paths.
MetadataCachingFileSystem(FileSystem, FileSystemContext) - Constructor for class alluxio.client.file.MetadataCachingFileSystem
 
metadataEnabled(AlluxioConfiguration) - Static method in class alluxio.client.file.FileSystemUtils
 
MetadataSyncLockManager - Class in alluxio.master.file
Class for managing metadata sync locking.
MetadataSyncLockManager() - Constructor for class alluxio.master.file.MetadataSyncLockManager
 
MetadataSyncLockManager.MetadataSyncPathList - Class in alluxio.master.file
Represents a locked path for a metadata sync path.
MetadataSyncMergeJournalContext - Class in alluxio.master.journal
A FileSystemMergeJournalContext used in MetadataSync (InodeSyncStream).
MetadataSyncMergeJournalContext(JournalContext, JournalEntryMerger) - Constructor for class alluxio.master.journal.MetadataSyncMergeJournalContext
MetadataSyncPathList() - Constructor for class alluxio.master.file.MetadataSyncLockManager.MetadataSyncPathList
 
MetadataSyncTraversalOrder - Enum in alluxio.master.file
The pending Path in the Inode SyncStream traversal order.
MetaMaster - Interface in alluxio.master.meta
The interface of meta master.
MetaMasterClient - Interface in alluxio.client.meta
Interface for a meta master client.
MetaMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients.
MetaMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients.
MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service MetaMasterClientService.
MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service MetaMasterClientService.
MetaMasterClientServiceGrpc.MetaMasterClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service MetaMasterClientService.
MetaMasterClientServiceGrpc.MetaMasterClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service MetaMasterClientService.
MetaMasterClientServiceHandler - Class in alluxio.master.meta
This class is a gRPC handler for meta master RPCs.
MetaMasterClientServiceHandler(MetaMaster) - Constructor for class alluxio.master.meta.MetaMasterClientServiceHandler
 
MetaMasterClientServiceImplBase() - Constructor for class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceImplBase
 
MetaMasterConfigClient - Interface in alluxio.client.meta
Interface for a meta master config client.
MetaMasterConfigurationServiceGrpc - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients to query cluster configuration.
MetaMasterConfigurationServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains meta master service endpoints for Alluxio clients to query cluster configuration.
MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service MetaMasterConfigurationService.
MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service MetaMasterConfigurationService.
MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service MetaMasterConfigurationService.
MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service MetaMasterConfigurationService.
MetaMasterConfigurationServiceHandler - Class in alluxio.master.meta
This class is a gRPC handler for meta master RPCs.
MetaMasterConfigurationServiceHandler(MetaMaster) - Constructor for class alluxio.master.meta.MetaMasterConfigurationServiceHandler
 
MetaMasterConfigurationServiceImplBase() - Constructor for class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceImplBase
 
MetaMasterFactory - Class in alluxio.master.meta
Factory to create a MetaMaster instance.
MetaMasterFactory() - Constructor for class alluxio.master.meta.MetaMasterFactory
Constructs a new MetaMasterFactory.
MetaMasterMasterServiceGrpc - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
MetaMasterMasterServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains meta master service endpoints for Alluxio standby masters.
MetaMasterMasterServiceGrpc.MetaMasterMasterServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service MetaMasterMasterService.
MetaMasterMasterServiceGrpc.MetaMasterMasterServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service MetaMasterMasterService.
MetaMasterMasterServiceGrpc.MetaMasterMasterServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service MetaMasterMasterService.
MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service MetaMasterMasterService.
MetaMasterMasterServiceHandler - Class in alluxio.master.meta
This class is a gRPC handler for meta master RPCs invoked by an Alluxio standby master.
MetaMasterMasterServiceHandler(MetaMaster) - Constructor for class alluxio.master.meta.MetaMasterMasterServiceHandler
Creates a new instance of MetaMasterMasterServiceHandler.
MetaMasterMasterServiceImplBase() - Constructor for class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceImplBase
 
MetaMasterProto - Class in alluxio.grpc
 
MetaMasterProxyServiceGrpc - Class in alluxio.grpc
This interface contains meta master service endpoints for Alluxio Proxy instances.
MetaMasterProxyServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains meta master service endpoints for Alluxio Proxy instances.
MetaMasterProxyServiceGrpc.MetaMasterProxyServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service MetaMasterProxyService.
MetaMasterProxyServiceGrpc.MetaMasterProxyServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service MetaMasterProxyService.
MetaMasterProxyServiceGrpc.MetaMasterProxyServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service MetaMasterProxyService.
MetaMasterProxyServiceGrpc.MetaMasterProxyServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service MetaMasterProxyService.
MetaMasterProxyServiceHandler - Class in alluxio.master.meta
This class is a gRPC handler for meta master RPCs invoked by an Alluxio standby master.
MetaMasterProxyServiceHandler(MetaMaster) - Constructor for class alluxio.master.meta.MetaMasterProxyServiceHandler
Creates a new instance of MetaMasterProxyServiceHandler.
MetaMasterProxyServiceImplBase() - Constructor for class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceImplBase
 
MetaMasterSync - Class in alluxio.master.meta
If a master is detected as a standby master.
MetaMasterSync(Address, RetryHandlingMetaMasterMasterClient) - Constructor for class alluxio.master.meta.MetaMasterSync
Creates a new instance of MetaMasterSync.
METASTORE_URI_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
METASTORE_URI_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
MetastoreType - Enum in alluxio.master.metastore
Metastore types.
MetastoreValidationTask<K,T> - Class in alluxio.cli.hms
A validation task which includes extra information in order to provide dependencies for sub-tasks along with the task's validation result.
MetastoreValidationTask(MetastoreValidationTask<?, K>) - Constructor for class alluxio.cli.hms.MetastoreValidationTask
Create a new MetastoreValidationTask with the given input task.
meter(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add meter with the given name.
METER_VALUE - Static variable in enum alluxio.grpc.MetricType
METER represents a metric value at a _rate_.
meterWithTags(String, boolean, String...) - Static method in class alluxio.metrics.MetricsSystem
Get or add meter with the given name.
Metric - Class in alluxio.grpc
Information about metrics.
Metric - Class in alluxio.metrics
A metric of a given instance.
Metric(MetricsSystem.InstanceType, String, MetricType, String, Double) - Constructor for class alluxio.metrics.Metric
Constructs a Metric instance.
Metric.Builder - Class in alluxio.grpc
Information about metrics.
METRIC_REGISTRY - Static variable in class alluxio.metrics.MetricsSystem
 
MetricInfo - Class in alluxio.metrics
Metric information.
MetricInfo.UfsOps - Enum in alluxio.metrics
The list of under filesystem operations triggered by master or workers.
MetricKey - Class in alluxio.metrics
Metric keys.
MetricKey.Builder - Class in alluxio.metrics
Builder to create MetricKey instances.
MetricKey.Name - Class in alluxio.metrics
A nested class to hold named string constants for their corresponding metrics.
MetricMasterProto - Class in alluxio.grpc
 
MetricOrBuilder - Interface in alluxio.grpc
 
Metrics() - Constructor for class alluxio.client.file.cache.PageStore.Metrics
 
METRICS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
METRICS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_EXECUTOR_TASK_WARN_FREQUENCY - Static variable in class alluxio.conf.PropertyKey
 
METRICS_EXECUTOR_TASK_WARN_FREQUENCY - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_EXECUTOR_TASK_WARN_SIZE - Static variable in class alluxio.conf.PropertyKey
 
METRICS_EXECUTOR_TASK_WARN_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPOptions
 
METRICS_FIELD_NUMBER - Static variable in class alluxio.grpc.ClientMetrics
 
METRICS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMetricsPResponse
 
METRICS_KEY_INCLUDING_UNIQUE_ID_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
METRICS_KEY_INCLUDING_UNIQUE_ID_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
METRICS_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
METRICS_MASTER_CLIENT_SERVICE = 9;
METRICS_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
METRICS_MASTER_NAME - Static variable in class alluxio.Constants
 
MetricsAggregator - Interface in alluxio.metrics
Interface for the aggregator that aggregates a cluster-level metric from the metrics of different hosts.
MetricsCommand - Class in alluxio.cli.fsadmin.command
Command for managing Alluxio metric system.
MetricsCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.MetricsCommand
 
MetricsCommand - Class in alluxio.cli.fsadmin.report
Prints Alluxio metrics information.
MetricsCommand(MetricsMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.MetricsCommand
Creates a new instance of MetricsCommand.
MetricsConfig - Class in alluxio.metrics
Configurations used by the metrics system.
MetricsConfig(String) - Constructor for class alluxio.metrics.MetricsConfig
Creates a new MetricsConfig using the given config file.
MetricsConfig(Properties) - Constructor for class alluxio.metrics.MetricsConfig
Creates a new MetricsConfig using the given Properties.
MetricsDocGenerator - Class in alluxio.cli.docgen
Generates metric key information in docs.
MetricsDocGenerator.FileWriterKey - Class in alluxio.cli.docgen
The key for a file writer.
MetricsFilter - Class in alluxio.metrics
A filter that matches the instance-level metrics by the instance type and metric name.
MetricsFilter(MetricsSystem.InstanceType, String) - Constructor for class alluxio.metrics.MetricsFilter
Constructs a new MetricsFilter instance.
metricsHeartbeat(MetricsHeartbeatPRequest, StreamObserver<MetricsHeartbeatPResponse>) - Method in interface alluxio.grpc.MetricsMasterClientServiceGrpc.AsyncService
Periodic metrics master client heartbeat.
metricsHeartbeat(MetricsHeartbeatPRequest) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceBlockingStub
Periodic metrics master client heartbeat.
metricsHeartbeat(MetricsHeartbeatPRequest) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub
Periodic metrics master client heartbeat.
metricsHeartbeat(MetricsHeartbeatPRequest, StreamObserver<MetricsHeartbeatPResponse>) - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub
Periodic metrics master client heartbeat.
metricsHeartbeat(MetricsHeartbeatPRequest, StreamObserver<MetricsHeartbeatPResponse>) - Method in class alluxio.master.metrics.MetricsMasterClientServiceHandler
 
MetricsHeartbeatContext - Class in alluxio.client.metrics
A class used to track metrics heartbeats to a master.
MetricsHeartbeatPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.MetricsHeartbeatPOptions
MetricsHeartbeatPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.MetricsHeartbeatPOptions
MetricsHeartbeatPOptionsOrBuilder - Interface in alluxio.grpc
 
MetricsHeartbeatPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.MetricsHeartbeatPRequest
MetricsHeartbeatPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.MetricsHeartbeatPRequest
MetricsHeartbeatPRequestOrBuilder - Interface in alluxio.grpc
 
MetricsHeartbeatPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.MetricsHeartbeatPResponse
MetricsHeartbeatPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.metric.MetricsHeartbeatPResponse
MetricsHeartbeatPResponseOrBuilder - Interface in alluxio.grpc
 
MetricsMaster - Interface in alluxio.master.metrics
Interface of the metrics master that aggregates the cluster-level metrics from workers and clients.
MetricsMasterClient - Interface in alluxio.client.metrics
Interface for a metrics master client.
MetricsMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains metrics master service endpoints for Alluxio clients.
MetricsMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains metrics master service endpoints for Alluxio clients.
MetricsMasterClientServiceGrpc.MetricsMasterClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service MetricsMasterClientService.
MetricsMasterClientServiceGrpc.MetricsMasterClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service MetricsMasterClientService.
MetricsMasterClientServiceGrpc.MetricsMasterClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service MetricsMasterClientService.
MetricsMasterClientServiceGrpc.MetricsMasterClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service MetricsMasterClientService.
MetricsMasterClientServiceHandler - Class in alluxio.master.metrics
This class is a gRPC handler for metrics master RPCs invoked by an Alluxio client.
MetricsMasterClientServiceHandler(MetricsMaster) - Constructor for class alluxio.master.metrics.MetricsMasterClientServiceHandler
 
MetricsMasterClientServiceImplBase() - Constructor for class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceImplBase
 
MetricsMasterFactory - Class in alluxio.master.metrics
Factory to create a MetricsMaster instance.
MetricsMasterFactory() - Constructor for class alluxio.master.metrics.MetricsMasterFactory
Constructs a new MetricsMasterFactory.
MetricsOutput - Class in alluxio.cli.fsadmin.report
An output class, describing the metrics.
MetricsOutput(Map<String, MetricValue>) - Constructor for class alluxio.cli.fsadmin.report.MetricsOutput
Creates a new instance of MetricsOutput.
MetricsService - Class in alluxio.master.service.metrics
Simple service that manages the behavior of the metrics system.
MetricsService() - Constructor for class alluxio.master.service.metrics.MetricsService
 
MetricsService.Factory - Class in alluxio.master.service.metrics
Factory that provides a simple service that manages the behavior of the metrics system.
MetricsServlet - Class in alluxio.metrics.sink
A sink that exposes metrics data in JSON format by HTTP.
MetricsServlet(MetricRegistry) - Constructor for class alluxio.metrics.sink.MetricsServlet
Creates a new MetricsServlet with a Properties and MetricRegistry.
MetricsStore - Class in alluxio.master.metrics
A store of metrics containing the metrics collected from workers and clients.
MetricsStore(Clock) - Constructor for class alluxio.master.metrics.MetricsStore
Constructs a new MetricsStore.
MetricsStore.ClusterCounterKey - Class in alluxio.master.metrics
The key for cluster counter map.
MetricsSystem - Class in alluxio.metrics
A MetricsSystem is created by a specific instance(master, worker).
MetricsSystem.InstanceType - Enum in alluxio.metrics
An enum of supported instance type.
MetricsSystem.MultiTimerContext - Class in alluxio.metrics
A timer context with multiple timers.
MetricType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.MetricType
METRICTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
 
METRICTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricValue
 
MetricValue - Class in alluxio.grpc
This type is used as a union, only one of doubleValue or stringValue should be set
MetricValue.Builder - Class in alluxio.grpc
This type is used as a union, only one of doubleValue or stringValue should be set
MetricValueOrBuilder - Interface in alluxio.grpc
 
mExecutorService - Variable in class alluxio.master.backup.AbstractBackupRole
The executor service.
mExecutorService - Variable in class alluxio.underfs.ObjectUnderFileSystem
Executor service used for parallel UFS operations such as bulk deletes.
mExistingJobAndProgresses - Variable in class alluxio.master.scheduler.Scheduler.SchedulerStats
 
mExpiryTimeMs - Variable in class alluxio.wire.RegisterLease
 
mExtendedEntries - Variable in class alluxio.security.authorization.AccessControlList
 
mFailedFiles - Variable in class alluxio.cli.fs.command.job.JobAttempt
 
mFailedTasks - Variable in class alluxio.cli.fs.command.job.JobAttempt
 
mFile - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The local temp file that will be uploaded when reaches the partition size or when flush() is called and this file is bigger than ObjectLowLevelOutputStream.UPLOAD_THRESHOLD.
mFileCount - Variable in class alluxio.dora.meta.DoraMetaBench.Db
 
mFileCount - Variable in class alluxio.fsmaster.FileSystemMasterBench.FileSystem
 
mFileCount - Variable in class alluxio.inode.InodeBenchRead.Db
 
mFileCount - Variable in class alluxio.inode.RocksBenchRead.Db
 
mFileCount - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mFileEntries - Variable in class alluxio.fuse.AlluxioJniFuseFileSystem
 
mFileGenerators - Variable in class alluxio.BaseFileStructure
 
mFileLength - Variable in class alluxio.underfs.ObjectPositionReader
Length of the file.
mFileSize - Variable in class alluxio.stress.client.ClientIOParameters
 
mFileSize - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mFilesToLoad - Variable in class alluxio.master.job.DoraLoadJob.DoraLoadTask
 
mFileSystem - Variable in class alluxio.cli.command.AbstractFuseShellCommand
 
mFileSystem - Variable in class alluxio.cli.fs.command.AbstractFileSystemCommand
 
mFileSystem - Variable in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
mFileSystem - Variable in class alluxio.hadoop.AbstractFileSystem
 
mFileSystem - Variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
mFree - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mFsClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mFsContext - Variable in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
 
mFsContext - Variable in class alluxio.cli.fs.command.AbstractFileSystemCommand
 
mFsContext - Variable in class alluxio.client.file.DoraCacheFileSystem
 
mFsContext - Variable in class alluxio.client.file.ufs.UfsBaseFileSystem
 
mFsContext - Variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
mFsContext - Variable in class alluxio.master.job.tracker.CmdJobTracker
 
mFuseFileSystem - Variable in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
mGraph - Variable in class alluxio.stress.graph.Graph
 
mGroup - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mGroup - Variable in class alluxio.underfs.UfsStatus
 
mGrpcMessagingContext - Variable in class alluxio.master.backup.AbstractBackupRole
Catalyst context used for sending/receiving messages.
mGrpcServer - Variable in class alluxio.master.service.rpc.RpcServerService
The grpc server and its executor service (RpcServerService.mRpcExecutor) need to be managed independently (i.e.
mHandler - Variable in class alluxio.proxy.s3.S3BaseTask
 
mHandler - Variable in class alluxio.worker.s3.S3NettyBaseTask
 
mHash - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The MD5 hash of the file.
mHashCode - Variable in class alluxio.uri.StandardURI
 
mHdfsAclProvider - Variable in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
mHelp - Variable in class alluxio.fuse.options.FuseCliOptions
 
mHelp - Variable in class alluxio.stress.BaseParameters
 
mHostname - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mHostName - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Address of the authentication host.
mId - Variable in class alluxio.master.file.meta.MutableInode
 
mId - Variable in class alluxio.stress.BaseParameters
 
mightContain(T) - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
Check whether an item is in cuckoo filter or not.
mightContain(T) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
mightContainAndResetClock(T) - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
Check whether an item is in cuckoo filter (and reset its clock to MAX) or not.
mightContainAndResetClock(T) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
MIGRATE_DATA_SESSION_ID - Static variable in class alluxio.Sessions
 
MigrateCliConfig - Class in alluxio.job.cmd.migrate
A config for a MigrateCli job.
MigrateCliConfig(String, String, WriteType, boolean, int) - Constructor for class alluxio.job.cmd.migrate.MigrateCliConfig
 
MigrateCliRunner - Class in alluxio.master.job.tracker
A config runner for a MigrateCli job.
MigrateCliRunner(FileSystemContext, JobMaster) - Constructor for class alluxio.master.job.tracker.MigrateCliRunner
constructor.
MigrateCommand - Class in alluxio.job.plan.migrate
A command telling a worker to migrate a file.
MigrateCommand(String, String) - Constructor for class alluxio.job.plan.migrate.MigrateCommand
 
MigrateConfig - Class in alluxio.job.plan.migrate
Configuration for the migrate job.
MigrateConfig(String, String, WriteType, boolean) - Constructor for class alluxio.job.plan.migrate.MigrateConfig
 
MigrateDefinition - Class in alluxio.job.plan.migrate
A job that migrates a single file from source path to a destination path.
MigrateDefinition() - Constructor for class alluxio.job.plan.migrate.MigrateDefinition
Constructs a new MigrateDefinition.
millis() - Method in class alluxio.clock.ElapsedTimeClock
 
millis() - Method in class alluxio.clock.SystemClock
 
MIN_VALUE - Static variable in enum alluxio.jnifuse.constants.Errno
 
mIndex - Variable in class alluxio.stress.BaseParameters
 
MiniBenchmark - Class in alluxio.cli
Mini benchmark that writes/reads one file with a given size and operation type.
minimalCompletionStage() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletionStage that is completed normally with the same value as this CompletableFuture when it completes normally, and cannot be independently completed or otherwise used in ways not defined by the methods of interface CompletionStage.
MINIMUM_PART_SIZE - Static variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
Only parts bigger than 5MB could be uploaded through multipart upload, except the last part.
mInodeTree - Variable in class alluxio.master.file.DefaultFileSystemMaster
This manages the file system inode structure.
mInProcess - Variable in class alluxio.stress.BaseParameters
 
mInputDir - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mInputStream - Variable in class alluxio.hadoop.BaseHdfsFileInputStream
 
mInputTask - Variable in class alluxio.cli.hms.MetastoreValidationTask
 
mInterruptedEvent - Variable in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
 
mIntervalSupplier - Variable in class alluxio.heartbeat.SleepingTimer
 
mIntervalSupplierSupplier - Variable in class alluxio.heartbeat.SleepingTimer
 
MINUTE - Static variable in class alluxio.Constants
 
MINUTE_MS - Static variable in class alluxio.Constants
 
MINUTE_SECONDS - Static variable in class alluxio.Constants
 
mInvalCount - Variable in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
mInvalDist - Variable in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
mIOBytes - Variable in class alluxio.stress.worker.WorkerBenchDataPoint
 
mIsDirectory - Variable in class alluxio.inode.RocksBenchRead.Db
 
mIsDirectory - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mIsDirectory - Variable in class alluxio.inode.RocksBenchWrite.ThreadState
 
mIsDirectory - Variable in class alluxio.underfs.UfsStatus
 
mIsRandom - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mIsRegistered - Variable in class alluxio.master.block.meta.MasterWorkerInfo
If true, the worker is considered registered.
MissingRequiredFieldsParsingException - Exception in alluxio.wire
Thrown when the parsed proto is missing any required field.
MissingRequiredFieldsParsingException(Throwable) - Constructor for exception alluxio.wire.MissingRequiredFieldsParsingException
 
MissingRequiredFieldsParsingException(Descriptors.FieldDescriptor, Message) - Constructor for exception alluxio.wire.MissingRequiredFieldsParsingException
Constructs a new exception with details of the missing field.
mIsStopped - Variable in class alluxio.master.AlluxioMasterProcess
mItems - Variable in class alluxio.master.file.meta.UfsSyncPathCache
 
mJavaOpts - Variable in class alluxio.stress.BaseParameters
 
mJobId - Variable in class alluxio.master.job.AbstractJob
 
mJobMap - Variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
mJobMaster - Variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
mJobMaster - Variable in class alluxio.master.job.tracker.CmdRunAttempt
 
mJobMasterClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mJobMasterJournalMasterClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mJournal - Variable in class alluxio.master.AbstractMaster
A handler to the journal for this master.
mJournalEntryFile - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mJournalEntryMerger - Variable in class alluxio.master.journal.FileSystemMergeJournalContext
 
mJournalSystem - Variable in class alluxio.master.backup.AbstractBackupRole
Journal system.
mJournalSystem - Variable in class alluxio.master.CoreMaster
 
mJournalSystem - Variable in class alluxio.master.MasterProcess
The journal system for writing journal entries and restoring master state.
mJsonFactory - Variable in class alluxio.web.JmxServlet
Json Factory to create Json generators for write objects in json format.
mkdir(String, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
mkdir(String, long) - Method in class alluxio.fuse.StackFS
 
mkdir(String, long) - Method in interface alluxio.jnifuse.FuseFileSystem
 
mkdirCallback(String, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
MkdirCommand - Class in alluxio.cli.fs.command
Creates a new directory specified by the path in args, including any parent folders that are required.
MkdirCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.MkdirCommand
Constructs a new instance to create a new directory.
mkdirIfNotExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Attempts to create the directory if it does not already exist.
mkdirs(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
mkdirs(Path, FsPermission) - Method in class alluxio.hadoop.AbstractFileSystem
Attempts to create a folder with the specified path.
mkdirs(Path, FsPermission) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
mkdirs(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
mkdirs(String) - Method in interface alluxio.underfs.UnderFileSystem
Creates the directory named by this abstract pathname.
mkdirs(String, MkdirsOptions) - Method in interface alluxio.underfs.UnderFileSystem
Creates the directory named by this abstract pathname, with specified MkdirsOptions.
mkdirs(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
mkdirsInternal(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates a directory flagged file with the key and folder suffix.
MkdirsOptions - Class in alluxio.underfs.options
Method options for mkdirs in UnderFileSystem.
mkdirsTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for creating directory.
mKey - Variable in class alluxio.master.metastore.caching.Cache.Entry
 
mKey - Variable in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
mKey - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Key of the file when it is uploaded to object storage.
mKey - Variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
Key of the file when it is uploaded to object storage.
mKey - Variable in class alluxio.underfs.s3a.S3AInputStream
The path of the object to read.
mKey - Variable in class alluxio.underfs.s3a.S3AOutputStream
Key of the file when it is uploaded to S3.
mLastModifiedTimeMs - Variable in class alluxio.underfs.UfsStatus
Last modified epoch time in ms, or null if it is not available.
mLeaderSelector - Variable in class alluxio.master.MasterProcess
 
mLeaseId - Variable in class alluxio.membership.AlluxioEtcdClient.Lease
 
mLeft - Variable in class alluxio.examples.Performance.Worker
 
mLength - Variable in class alluxio.network.protocol.databuffer.NioDataBuffer
 
mLocalOutputStream - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The output stream to the local temp file.
mLocation - Variable in class alluxio.master.journalv0.ufs.UfsJournal
The location where this journal is stored.
mLock - Variable in class alluxio.client.file.cache.DefaultPageMetaStore
 
mLock - Variable in class alluxio.membership.DefaultServiceEntity
 
mLock - Variable in class alluxio.resource.LockResource
 
mLockList - Variable in class alluxio.master.file.meta.LockedInodePath
Lock list locking some portion of the path according to mLockPattern.
mLockPattern - Variable in class alluxio.master.file.meta.LockedInodePath
The locking pattern.
mLogger - Variable in class alluxio.heartbeat.FixedIntervalSupplier
 
mLogger - Variable in class alluxio.heartbeat.SleepingTimer
 
mLRUCache - Variable in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
mManager - Variable in class alluxio.underfs.s3a.S3AOutputStream
A TransferManager to upload the file to S3 using Multipart Uploads.
mMaskActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
mMaster - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mMasterContext - Variable in class alluxio.master.AbstractMaster
The context of Alluxio masters.
mMasterInquireClient - Variable in class alluxio.master.MasterClientContextBuilder
 
mMasterJournalMasterClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mMasterProcess - Variable in class alluxio.master.service.rpc.RpcServerService
 
mMasterRegistry - Variable in class alluxio.master.service.rpc.RpcServerService
 
mMaxCapacity - Variable in class alluxio.resource.ResourcePool
 
mMaxResponseTimeNs - Variable in class alluxio.stress.common.TaskResultStatistics
 
mMaxSizeBits - Variable in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
 
mMaxSpeedMbps - Variable in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
mMaxTimeMs - Variable in class alluxio.stress.common.SummaryStatistics
max time over time, over the duration of the test.
mMean - Variable in class alluxio.job.util.TimeSeries.Summary
 
mMessage - Variable in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
mMetaClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mMetadataLoad - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mMetricsClient - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mMinSpeedMbps - Variable in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
mMode - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mMode - Variable in class alluxio.security.authorization.AccessControlList
 
mMode - Variable in class alluxio.stress.worker.IOTaskResult.Point
 
mMode - Variable in class alluxio.underfs.UfsStatus
 
mMountCliOptions - Variable in class alluxio.fuse.options.FuseCliOptions
 
mMountOptions - Variable in class alluxio.fuse.options.MountCliOptions
 
mMountOptions - Variable in class alluxio.fuse.options.MountOptions
 
mMountPoint - Variable in class alluxio.fuse.options.FuseCliOptions
 
mMountPoint - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mMyId - Variable in class alluxio.BaseThreadState
 
mMyJob - Variable in class alluxio.scheduler.job.Task
 
mName - Variable in class alluxio.underfs.UfsStatus
 
mNamedGroupActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
mNamedUserActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
mNeedReconnect - Variable in class alluxio.membership.DefaultServiceEntity
 
mNodeResults - Variable in class alluxio.stress.common.GeneralBenchSummary
 
mNumBuckets - Variable in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
 
mNumConcurrentAsyncCalls - Variable in class alluxio.fsmaster.FileSystemBench.FileSystem
 
mNumGrpcChannels - Variable in class alluxio.fsmaster.FileSystemBench.FileSystem
 
mNumSuccesses - Variable in class alluxio.stress.common.SummaryStatistics
number of successes.
mNumSuccesses - Variable in class alluxio.stress.common.TaskResultStatistics
 
mObjectMapper - Variable in class alluxio.web.WebInterfaceAbstractMetricsServlet
 
Mode - Enum in alluxio.job.plan.replicate
setReplication Mode.
Mode - Class in alluxio.security.authorization
POSIX style file/directory access mode.
Mode(Mode.Bits, Mode.Bits, Mode.Bits) - Constructor for class alluxio.security.authorization.Mode
Constructs an instance of Mode with the given Mode.Bits.
Mode(short) - Constructor for class alluxio.security.authorization.Mode
Constructs an instance of Mode with the given mode.
Mode(Mode) - Constructor for class alluxio.security.authorization.Mode
Copy constructor.
Mode.Bits - Enum in alluxio.security.authorization
Mode bits.
MODE_BITS_ALL - Static variable in class alluxio.Constants
 
MODE_BITS_EXECUTE - Static variable in class alluxio.Constants
 
MODE_BITS_NONE - Static variable in class alluxio.Constants
 
MODE_BITS_READ - Static variable in class alluxio.Constants
 
MODE_BITS_READ_EXECUTE - Static variable in class alluxio.Constants
 
MODE_BITS_READ_WRITE - Static variable in class alluxio.Constants
 
MODE_BITS_WRITE - Static variable in class alluxio.Constants
 
MODE_BITS_WRITE_EXECUTE - Static variable in class alluxio.Constants
 
MODE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
MODE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
MODE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
MODE_FIELD_NUMBER - Static variable in class alluxio.grpc.PAcl
 
MODE_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
MODE_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
MODE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
MODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
MODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
MODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
MODE_NOT_SET_VALUE - Static variable in class alluxio.fuse.AlluxioFuseUtils
 
ModeParser - Class in alluxio.security.authorization
Parser for Mode instances.
ModeUtils - Class in alluxio.util
Utility methods for mode.
modifiableGlobal() - Static method in class alluxio.conf.Configuration
 
MODIFY_VALUE - Static variable in enum alluxio.grpc.SetAclAction
MODIFY = 1;
MODIFY_VALUE - Static variable in enum alluxio.proto.journal.File.PSetAclAction
MODIFY = 1;
mOperation - Variable in class alluxio.dora.meta.DoraMetaBench.Db
 
mOperation - Variable in class alluxio.stress.client.ClientIOParameters
 
mOperationTimeMs - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mOpts - Variable in class alluxio.fsmaster.FileSystemBench.ThreadState
 
mOPType - Variable in class alluxio.proxy.s3.S3BaseTask
 
mOPType - Variable in class alluxio.worker.s3.S3NettyBaseTask
 
MOSTSIGNIFICANTBITS_FIELD_NUMBER - Static variable in class alluxio.grpc.FsOpPId
 
MOSTSIGNIFICANTBITS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalOpPId
 
mount(AlluxioURI, AlluxioURI, MountPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
mount(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.mount(AlluxioURI, AlluxioURI, MountPOptions) with default options.
mount(AlluxioURI, AlluxioURI, MountPOptions) - Method in interface alluxio.client.file.FileSystem
Mounts a UFS subtree to the given Alluxio path.
mount(AlluxioURI, AlluxioURI, MountPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
mount(AlluxioURI, AlluxioURI, MountPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Mounts the given UFS path under the given Alluxio path.
mount(AlluxioURI, AlluxioURI, MountPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
mount(AlluxioURI, AlluxioURI, MountPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
mount(MountPRequest, StreamObserver<MountPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Creates a new "mount point", mounts the given UFS path in the Alluxio namespace at the given path.
mount(MountPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Creates a new "mount point", mounts the given UFS path in the Alluxio namespace at the given path.
mount(MountPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Creates a new "mount point", mounts the given UFS path in the Alluxio namespace at the given path.
mount(MountPRequest, StreamObserver<MountPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Creates a new "mount point", mounts the given UFS path in the Alluxio namespace at the given path.
mount(boolean, boolean, Set<String>) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
Executes mount command.
Mount - Class in alluxio.master.backcompat.ops
Test for mounting and unmounting.
Mount() - Constructor for class alluxio.master.backcompat.ops.Mount
 
mount(AlluxioURI, AlluxioURI, MountContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
mount(AlluxioURI, AlluxioURI, MountContext) - Method in interface alluxio.master.file.FileSystemMaster
Mounts a UFS path onto an Alluxio path.
mount(MountPRequest, StreamObserver<MountPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
MOUNT - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
mount(String, String, MountPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
MOUNT_COMMAND - Static variable in class alluxio.util.ShellUtils
a Unix command for getting mount information.
MOUNT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
MOUNT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
MOUNT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
MOUNT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddSyncPointEntry
 
MOUNT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
MOUNT_OPTION - Static variable in class alluxio.conf.Source
 
MOUNT_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
MOUNT_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
MountCliOptions - Class in alluxio.fuse.options
Mount options specified with -o from the command line.
MountCliOptions() - Constructor for class alluxio.fuse.options.MountCliOptions
 
MountContext - Class in alluxio.master.file.contexts
Used to merge and wrap MountPOptions.
mountDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.Block
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.File
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMountIdPResponse
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetUfsInfoPRequest
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
MOUNTID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
MountInfo - Class in alluxio.master.file.meta.options
This class holds information about a mount point.
MountInfo(AlluxioURI, AlluxioURI, long, MountPOptions) - Constructor for class alluxio.master.file.meta.options.MountInfo
Creates a new instance of MountInfo.
MountOptions - Class in alluxio.fuse.options
Options for an Alluxio Fuse mount point.
MountOptions(Map<String, String>) - Constructor for class alluxio.fuse.options.MountOptions
Constructor.
MOUNTPOINT_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
MountPointInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPointInfo
MountPointInfo - Class in alluxio.wire
The mount point information.
MountPointInfo() - Constructor for class alluxio.wire.MountPointInfo
Creates a new instance of MountPointInfo.
MountPointInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPointInfo
MountPointInfoOrBuilder - Interface in alluxio.grpc
 
MOUNTPOINTS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMountTablePResponse
 
MountPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPOptions
MountPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPOptions
MountPOptionsOrBuilder - Interface in alluxio.grpc
 
MountPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPRequest
MountPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPRequest
MountPRequestOrBuilder - Interface in alluxio.grpc
 
MountPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPResponse
MountPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MountPResponse
MountPResponseOrBuilder - Interface in alluxio.grpc
 
MountTable - Class in alluxio.master.file.meta
This class is used for keeping track of Alluxio mount points.
MountTable(UfsManager, MountInfo, Clock) - Constructor for class alluxio.master.file.meta.MountTable
Creates a new instance of MountTable.
MountTable.Resolution - Class in alluxio.master.file.meta
This class represents a UFS path after resolution.
MountTable.ReverseResolution - Class in alluxio.master.file.meta
This class represents a Alluxio path after reverse resolution.
MountTable.State - Class in alluxio.master.file.meta
Persistent mount table state.
mOutputDir - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mOutputErrorEvent - Variable in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
 
move(MoveRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
move files from src to dst.
move(MoveRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
move(MoveRequest, StreamObserver<MoveResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
move(MoveRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
move(MoveRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
move(MoveRequest, StreamObserver<MoveResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
move(String, String) - Static method in class alluxio.util.io.FileUtils
Moves file from one place to another, can across storage devices (e.g., from memory to SSD) when File.renameTo(java.io.File) may not work.
move(List<Route>, UfsReadOptions, WriteOptions) - Method in interface alluxio.worker.dora.DoraWorker
Moves files from src to dst.
move(List<Route>, UfsReadOptions, WriteOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
move(MoveRequest, StreamObserver<MoveResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
MOVE_FAIL_FILE_COUNT - Static variable in class alluxio.master.job.MoveJob
 
MOVE_FILE_COUNT - Static variable in class alluxio.master.job.MoveJob
 
MOVE_JOB_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
MOVE_RATE - Static variable in class alluxio.master.job.MoveJob
 
MOVE_SIZE - Static variable in class alluxio.master.job.MoveJob
 
moveBlock(MoveBlockRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Move a block from worker.
moveBlock(MoveBlockRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
moveBlock(MoveBlockRequest, StreamObserver<MoveBlockResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
moveBlock(MoveBlockRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
moveBlock(MoveBlockRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
moveBlock(MoveBlockRequest, StreamObserver<MoveBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
moveBlock(long, long, AllocateOptions) - Method in interface alluxio.worker.block.BlockStore
Moves an existing block to a new location.
moveBlock(long, long, String) - Method in interface alluxio.worker.block.BlockWorker
Moves a block from its current location to a target location, currently only tier level moves are supported.
MoveBlockRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveBlockRequest
MoveBlockRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveBlockRequest
MoveBlockRequestOrBuilder - Interface in alluxio.grpc
 
MoveBlockResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveBlockResponse
MoveBlockResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveBlockResponse
MoveBlockResponseOrBuilder - Interface in alluxio.grpc
 
MoveConfig - Class in alluxio.job.plan.replicate
Configuration of a job moving a block.
MoveConfig(String, long, String, String) - Constructor for class alluxio.job.plan.replicate.MoveConfig
Creates a new instance of MoveConfig.
MoveDefinition - Class in alluxio.job.plan.replicate
A job to move a block.
MoveDefinition() - Constructor for class alluxio.job.plan.replicate.MoveDefinition
Constructs a new MoveDefinition.
MoveJob - Class in alluxio.master.job
Move job that move a file or a directory from source to destination.
MoveJob(String, String, boolean, Optional<String>, String, OptionalLong, boolean, boolean, boolean, Iterable<FileInfo>, Optional<Job.FileFilter>) - Constructor for class alluxio.master.job.MoveJob
Constructor.
MoveJob.MoveTask - Class in alluxio.master.job
Moves blocks in a UFS through an Alluxio worker.
MoveJobFactory - Class in alluxio.master.job
Factory for creating MoveJobs that get file infos from master.
MoveJobFactory(MoveJobRequest, DefaultFileSystemMaster) - Constructor for class alluxio.master.job.MoveJobFactory
Create factory.
MoveJobPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MoveJobPOptions
MoveJobPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.MoveJobPOptions
MoveJobPOptionsOrBuilder - Interface in alluxio.grpc
 
MoveJobRequest - Class in alluxio.job
The request of moving files.
MoveJobRequest(String, String, MoveJobPOptions) - Constructor for class alluxio.job.MoveJobRequest
 
MoveRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveRequest
MoveRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveRequest
MoveRequestOrBuilder - Interface in alluxio.grpc
 
MoveResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveResponse
MoveResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.MoveResponse
MoveResponseOrBuilder - Interface in alluxio.grpc
 
MoveTask(List<Route>) - Constructor for class alluxio.master.job.MoveJob.MoveTask
Creates a new instance of MoveJob.MoveTask.
mOwner - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mOwner - Variable in class alluxio.underfs.UfsStatus
 
mOwningGroup - Variable in class alluxio.security.authorization.AccessControlList
 
mOwningUser - Variable in class alluxio.security.authorization.AccessControlList
 
mPageSize - Variable in class alluxio.client.file.cache.LocalCacheFileInStream
Page size in bytes.
mPageSize - Variable in class alluxio.client.file.cache.LocalCachePositionReader
Page size in bytes.
mParameters - Variable in class alluxio.stress.cli.AbstractStressBench
 
mParentCommandName - Variable in class alluxio.cli.command.AbstractFuseShellCommand
 
mPartialRequest - Variable in class alluxio.client.file.dora.netty.NettyDataWriter
 
mPartitionOffset - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
When the offset reaches the partition size, we upload the temp file.
mPartitionOffset - Variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
When the offset reaches the partition size, we upload mStream.
mPartitionSize - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The maximum allowed size of a partition.
mPartitionSize - Variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
The maximum allowed size of a partition.
mPath - Variable in class alluxio.stress.worker.UfsIOParameters
 
mPath - Variable in class alluxio.underfs.ObjectPositionReader
Path of the file when it is uploaded to object storage.
mPath - Variable in class alluxio.uri.StandardURI
 
mPathComponents - Variable in class alluxio.master.file.meta.LockedInodePath
The components of mUri.
mPathResolverCache - Variable in class alluxio.fuse.AlluxioJniFuseFileSystem
 
mPeak - Variable in class alluxio.job.util.TimeSeries.Summary
 
mPool - Variable in class alluxio.resource.PooledResource
 
mPoolDescription - Variable in class alluxio.resource.PooledResource
 
mPort - Variable in class alluxio.master.CoreMaster
 
mPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The current position of the stream.
mPos - Variable in class alluxio.underfs.s3a.S3AInputStream
The current position of the stream.
mPosToRead - Variable in class alluxio.client.block.stream.BufferCachingGrpcDataReader
The next pos to read.
mPosToWrite - Variable in class alluxio.worker.netty.WriteRequestContext
The next pos to write to the block worker.
mPreviousTickedMs - Variable in class alluxio.heartbeat.SleepingTimer
 
mPrimaryMasterAddress - Variable in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
mPrimarySelector - Variable in class alluxio.master.CoreMaster
 
mPrintStream - Variable in class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
mProfileAgent - Variable in class alluxio.stress.BaseParameters
 
mProperties - Variable in class alluxio.conf.InstancedConfiguration
Source of the truth of all property values (default or customized).
mProxyProcess - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mProxyThread - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mQuery - Variable in class alluxio.uri.StandardURI
 
mRandomMaxReadLength - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mRandomMinReadLength - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mRandomSeed - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mReadRandom - Variable in class alluxio.stress.client.ClientIOParameters
 
mReadRequest - Variable in class alluxio.underfs.s3a.S3AInputStream
 
mReadSameFile - Variable in class alluxio.stress.client.ClientIOParameters
 
mReadType - Variable in class alluxio.inode.RocksBenchRead.Db
 
mReadType - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mReadType - Variable in class alluxio.stress.common.FileSystemParameters
 
mRecursive - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mRecursiveOperationForceFlushEntries - Variable in class alluxio.master.file.DefaultFileSystemMaster
 
mRefCount - Variable in class alluxio.rocks.RocksStore
 
mRegistry - Variable in class alluxio.master.MasterProcess
The master registry.
mRejectingGrpcServer - Variable in class alluxio.master.service.rpc.RpcServerService
 
mResources - Variable in class alluxio.resource.DynamicResourcePool
 
mResources - Variable in class alluxio.resource.ResourcePool
 
mResponseTimeNsRaw - Variable in class alluxio.stress.common.TaskResultStatistics
 
mRetryPolicy - Variable in class alluxio.cli.fs.command.job.JobAttempt
 
mRetryPolicy - Variable in class alluxio.master.job.tracker.CmdRunAttempt
 
mRetryPolicy - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The retry policy of this multipart upload.
mRetryPolicy - Variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
The retry policy of this multipart upload.
mRetryPolicy - Variable in class alluxio.underfs.s3a.S3AInputStream
Policy determining the retry behavior in case the key does not exist.
mRetryTaskList - Variable in class alluxio.master.job.AbstractJob
 
mRevision - Variable in class alluxio.membership.DefaultServiceEntity
 
mRight - Variable in class alluxio.examples.Performance.Worker
 
mRocksConfig - Variable in class alluxio.inode.InodeBenchRead.Db
 
mRocksConfig - Variable in class alluxio.inode.InodeBenchWrite.Db
 
mRocksConfig - Variable in class alluxio.inode.RocksBenchRead.Db
 
mRocksConfig - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mRocksConfig - Variable in class alluxio.inode.RocksBenchWrite.Db
 
mRocksDbStopServing - Variable in class alluxio.rocks.RocksStore
 
mRoleClosed - Variable in class alluxio.master.backup.AbstractBackupRole
Whether the role is active.
mRootKeySupplier - Variable in class alluxio.underfs.ObjectUnderFileSystem
The root key of an object fs.
mRootUfsUri - Variable in class alluxio.fuse.options.FuseCliOptions
 
mRpcExecutor - Variable in class alluxio.master.service.rpc.RpcServerService
 
mRunningJobToTasksStat - Variable in class alluxio.master.scheduler.Scheduler.SchedulerStats
 
MS_NANO - Static variable in class alluxio.Constants
 
mSafeModeManager - Variable in class alluxio.master.AlluxioMasterProcess
The manager of safe mode state.
mSafeModeManager - Variable in class alluxio.master.CoreMaster
 
mSaslClient - Variable in class alluxio.security.authentication.AbstractSaslClientHandler
Underlying SaslClient.
mSaslServer - Variable in class alluxio.security.authentication.AbstractSaslServerHandler
Underlying SaslServer.
mScheduler - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Scheduler for periodic cleaning of channels registry.
mScheme - Variable in class alluxio.uri.StandardURI
A hierarchical URI.
mSchemeSpecificPart - Variable in class alluxio.uri.StandardURI
 
mSelectionPolicy - Variable in class alluxio.resource.DynamicResourcePool
the selection policy of the resource pool.
mServerAddress - Variable in class alluxio.AbstractClient
Grpc Address of the remote server.
mServerErrorEvent - Variable in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
 
mServerType - Variable in class alluxio.fsmaster.FileSystemBench.FileSystem
 
mServerUserState - Variable in class alluxio.master.backup.AbstractBackupRole
User information for server.
mServiceDiscovery - Variable in class alluxio.membership.AlluxioEtcdClient
 
mServiceEntityName - Variable in class alluxio.membership.DefaultServiceEntity
 
mServiceVersion - Variable in class alluxio.AbstractClient
Stores the actual remote service version, used to compare with expected local version.
mServletContextHandler - Variable in class alluxio.web.WebServer
 
MSG_FIELD_NUMBER - Static variable in class alluxio.grpc.TransferLeaderMessage
 
mSingleByteHolder - Variable in class alluxio.underfs.s3a.S3AInputStream
 
mSingleCharWrite - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Pre-allocated byte buffer for writing single characters.
mSingleCharWrite - Variable in class alluxio.underfs.ObjectMultipartUploadOutputStream
Pre-allocated byte buffer for writing single characters.
mSingleFile - Variable in class alluxio.inode.InodeBenchRead.Db
 
mSizeGroupBits - Variable in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
 
mSkipCreation - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mSleeper - Variable in class alluxio.heartbeat.SleepingTimer
 
mSliceSize - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mStart - Variable in class alluxio.master.journal.tool.AbstractJournalDumper
 
mStartMs - Variable in class alluxio.stress.BaseParameters
 
mStartTime - Variable in class alluxio.master.job.AbstractJob
 
mStartTimeMs - Variable in class alluxio.master.CoreMaster
 
mState - Variable in class alluxio.master.file.meta.MountTable
Mount table state that is preserved across restarts.
mState - Variable in class alluxio.master.job.AbstractJob
 
mStateLockCallTracker - Variable in class alluxio.master.file.DefaultFileSystemMaster
Used to check pending/running backup from RPCs.
mStddev - Variable in class alluxio.job.util.TimeSeries.Summary
 
mStdDev - Variable in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
mStream - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The backing input stream.
mSubject - Variable in class alluxio.security.user.BaseUserState
 
mSubmitted - Variable in class alluxio.master.job.tracker.AbstractCmdRunner
 
mSubmittedJobAttempts - Variable in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
mSubTitle - Variable in class alluxio.stress.graph.Graph
 
mTag - Variable in class alluxio.stress.client.ClientIOParameters
 
mTag - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mTaskIdGenerator - Variable in class alluxio.master.job.AbstractJob
 
mTaskScheduler - Variable in class alluxio.master.backup.AbstractBackupRole
Task scheduler.
mThreads - Variable in class alluxio.stress.client.ClientIOParameters
 
mThreads - Variable in class alluxio.stress.worker.UfsIOParameters
 
mThreads - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mThroughput - Variable in class alluxio.stress.common.GeneralBenchSummary
 
mTime99PercentileMs - Variable in class alluxio.stress.common.SummaryStatistics
percentiles of just 99.x%.
mTimeoutEvent - Variable in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
 
mTimePercentileMs - Variable in class alluxio.stress.common.SummaryStatistics
response times for all percentiles from 0 -> 100 (101 values).
mTitle - Variable in class alluxio.stress.graph.Graph
 
mTmpDirs - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
 
mTotalDurationSeconds - Variable in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
mTotalSizeBytes - Variable in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
mTtl - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mTtl - Variable in class alluxio.master.file.meta.MutableInode
 
mTtlAction - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mTtlAction - Variable in class alluxio.master.file.meta.MutableInode
 
mTtlInSec - Variable in class alluxio.membership.AlluxioEtcdClient.Lease
 
mType - Variable in class alluxio.conf.Source
 
mType - Variable in class alluxio.dora.meta.DoraMetaBench.Db
 
mType - Variable in class alluxio.inode.InodeBenchRead.Db
 
mType - Variable in class alluxio.inode.InodeBenchWrite.Db
 
mUfs - Variable in class alluxio.client.file.ufs.UfsBaseFileSystem
 
mUfsConf - Variable in class alluxio.underfs.BaseUnderFileSystem
UFS Configuration options.
mUfsFullPath - Variable in class alluxio.underfs.UfsStatus
 
mUfsManager - Variable in class alluxio.master.backup.AbstractBackupRole
The manager of all ufs.
mUfsManager - Variable in class alluxio.worker.dora.PagedDoraWorker
 
MULTI_MASTER_URI - Static variable in class alluxio.multi.process.PortCoordination
 
MULTI_MASTERS_AUTH - Static variable in interface alluxio.uri.Authority
 
MULTI_PROCESS_SIMPLE_CLUSTER - Static variable in class alluxio.multi.process.PortCoordination
 
MULTI_PROCESS_ZOOKEEPER - Static variable in class alluxio.multi.process.PortCoordination
 
MultiChunkEncodingInputStream - Class in alluxio.s3
This input stream decodes a set of aws-chunked encoded input content buffer into its original form.
MultiChunkEncodingInputStream(ByteBuf) - Constructor for class alluxio.s3.MultiChunkEncodingInputStream
Constructs an MultiChunkEncodingInputStream with first currentContent.
MultiMasterAuthority - Class in alluxio.uri
A multi-master authority implementation.
MultiMasterAuthority(String) - Constructor for class alluxio.uri.MultiMasterAuthority
 
MultiMasterConnectDetails(List<InetSocketAddress>) - Constructor for class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
MultiMasterEmbeddedJournalLocalAlluxioCluster - Class in alluxio.master
A local Alluxio cluster with multiple masters using embedded journal.
MultiMasterEmbeddedJournalLocalAlluxioCluster(int, int, List<PortCoordination.ReservedPort>) - Constructor for class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
MultiMasterLocalAlluxioCluster - Class in alluxio.master
A local Alluxio cluster with multiple masters.
MultiMasterLocalAlluxioCluster(int) - Constructor for class alluxio.master.MultiMasterLocalAlluxioCluster
Runs a multi master local Alluxio cluster with a single worker.
MultiMasterLocalAlluxioCluster(int, int) - Constructor for class alluxio.master.MultiMasterLocalAlluxioCluster
 
MultiMount - Class in alluxio.examples
Example program that demonstrates Alluxio's ability to read and write data across different types of storage systems.
MULTIPART_CLEANER_ENABLED - Static variable in class alluxio.proxy.s3.S3Handler
 
MULTIPART_COPY_THRESHOLD - Static variable in class alluxio.underfs.s3a.S3AUnderFileSystem
Threshold to do multipart copy.
MULTIPART_UPLOADS_METADATA_DIR - Static variable in class alluxio.proxy.s3.S3RestUtils
 
MultiPartSchemeURI - Class in alluxio.uri
MultiPartSchemeURI supports multiple components for the scheme.
MultiPartSchemeURI(String, String, Authority, String, String) - Constructor for class alluxio.uri.MultiPartSchemeURI
 
MultiPartSchemeURI(URI, String, String) - Constructor for class alluxio.uri.MultiPartSchemeURI
Constructs a new URI from a base URI, but with a new path component.
MultipartUploadCleaner - Class in alluxio.proxy.s3
A lazy method (not scan the whole fileSystem to find tmp directory) to support automatic abortion s3 multipartUpload after a timeout.
MultipartUploadCleaner.AbortTask - Class in alluxio.proxy.s3
Abort Multipart upload task.
MultipartUploader - Interface in alluxio.underfs
The multipart uploader interface to support multipart uploading.
MultipleBloomShadowCacheManager - Class in alluxio.client.file.cache
This class is a shadow cache with multiple bloom filter implementation.
MultipleBloomShadowCacheManager(AlluxioConfiguration) - Constructor for class alluxio.client.file.cache.MultipleBloomShadowCacheManager
Create a MultipleBloomShadowCacheManager.
MultiProcessCluster - Class in alluxio.multi.process
Class for starting, stopping, and interacting with an Alluxio cluster where each master and worker runs in its own process.
MultiProcessCluster.Builder - Class in alluxio.multi.process
Builder for MultiProcessCluster.
MultiProcessCluster.DeployMode - Enum in alluxio.multi.process
Deploy mode for the cluster.
MultiRangeObjectInputStream - Class in alluxio.underfs
A stream for reading data using range queries.
MultiRangeObjectInputStream(long) - Constructor for class alluxio.underfs.MultiRangeObjectInputStream
Creates the input stream that will perform reads with a specified chunk size.
MultiTimerContext(Timer...) - Constructor for class alluxio.metrics.MetricsSystem.MultiTimerContext
 
MultiValueMetricsAggregator - Interface in alluxio.metrics
An interface for the aggregator that aggregates metrics of different hosts into multiple cluster-level metrics.
mUnderFileSystemMap - Variable in class alluxio.underfs.AbstractUfsManager
Maps from key to UnderFileSystem instances.
mUpdateCheck - Variable in class alluxio.fuse.options.FuseCliOptions
 
mUploadId - Variable in class alluxio.underfs.cos.COSMultipartUploadOutputStream
The upload id of this multipart upload.
mUploadId - Variable in class alluxio.underfs.obs.OBSLowLevelOutputStream
The upload id of this multipart upload.
mUploadId - Variable in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
The upload id of this multipart upload.
mUploadId - Variable in class alluxio.underfs.oss.OSSLowLevelOutputStream
The upload id of this multipart upload.
mUploadId - Variable in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
The upload id of this multipart upload.
mUploadId - Variable in class alluxio.underfs.s3a.S3ALowLevelOutputStream
The upload id of this multipart upload.
mUploadId - Variable in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
The upload id of this multipart upload.
mUri - Variable in class alluxio.client.file.DoraFileOutStream
 
mURI - Variable in class alluxio.fsmaster.FileSystemBench.ThreadState
 
mUri - Variable in class alluxio.master.file.meta.LockedInodePath
Uri for the path represented.
mUri - Variable in class alluxio.underfs.BaseUnderFileSystem
The UFS AlluxioURI used to create this BaseUnderFileSystem.
mUser - Variable in class alluxio.master.job.AbstractJob
 
mUser - Variable in class alluxio.security.user.BaseUserState
 
mUseSerialization - Variable in class alluxio.inode.RocksBenchWrite.Db
 
mUseUfsConf - Variable in class alluxio.stress.worker.UfsIOParameters
 
MUST_CACHE_VALUE - Static variable in enum alluxio.grpc.WritePType
Deprecated.
MutableInode<T extends MutableInode> - Class in alluxio.master.file.meta
MutableInode is an abstract class, with information shared by all types of Inodes.
MutableInode(long, boolean) - Constructor for class alluxio.master.file.meta.MutableInode
 
MutableInodeDirectory - Class in alluxio.master.file.meta
Alluxio file system's directory representation in the file system master.
MutableInodeFile - Class in alluxio.master.file.meta
Alluxio file system's file representation in the file system master.
MutableJournal - Interface in alluxio.master.journalv0
The read-write journal.
MutableJournal.Factory - Class in alluxio.master.journalv0
A MutableJournal factory.
mValue - Variable in class alluxio.master.metastore.caching.Cache.Entry
 
MvCommand - Class in alluxio.cli.fs.command
Renames a file or directory specified by args.
MvCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.MvCommand
 
mVersionId - Variable in class alluxio.s3.DeleteObjectsResult.ErrorObject
 
mVersionService - Variable in class alluxio.AbstractClient
 
mWarmup - Variable in class alluxio.stress.client.ClientIOParameters
 
mWarmup - Variable in class alluxio.stress.worker.WorkerBenchParameters
 
mWidth - Variable in class alluxio.fsmaster.FileSystemMasterBench.FileSystem
 
mWidth - Variable in class alluxio.inode.InodeBenchRead.Db
 
mWidth - Variable in class alluxio.inode.InodeBenchWrite.Db
 
mWidth - Variable in class alluxio.inode.RocksBenchRead.Db
 
mWidth - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mWidth - Variable in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
mWidthGenerator - Variable in class alluxio.BaseFileStructure
 
mWorkDirectory - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkerAssignPolicy - Variable in class alluxio.master.job.AbstractJob
 
mWorkerId - Variable in class alluxio.examples.Performance.Worker
 
mWorkerInfo - Variable in class alluxio.master.scheduler.Scheduler.WorkerInfoIdentity
 
mWorkerQInfos - Variable in class alluxio.master.scheduler.Scheduler.SchedulerStats
 
mWorkers - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkerThreads - Variable in class alluxio.master.AbstractLocalAlluxioCluster
 
mWorkingDirPath - Variable in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
 
mWriteNumWorkers - Variable in class alluxio.stress.client.ClientIOParameters
 
mWritePercentage - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mWriteSerialization - Variable in class alluxio.inode.RocksBenchReadWrite.Db
 
mWriteType - Variable in class alluxio.stress.common.FileSystemParameters
 
mXAttr - Variable in class alluxio.master.file.contexts.CreatePathContext
 
mXAttr - Variable in class alluxio.underfs.UfsStatus
 
mXAttrPropStrat - Variable in class alluxio.master.file.contexts.CreatePathContext
 

N

NAME - Static variable in class alluxio.job.cmd.migrate.MigrateCliConfig
 
NAME - Static variable in class alluxio.job.cmd.persist.PersistCmdConfig
 
NAME - Static variable in class alluxio.job.plan.BatchedJobConfig
 
NAME - Static variable in class alluxio.job.plan.migrate.MigrateConfig
 
NAME - Static variable in class alluxio.job.plan.NoopPlanConfig
 
NAME - Static variable in class alluxio.job.plan.persist.PersistConfig
 
NAME - Static variable in class alluxio.job.plan.replicate.MoveConfig
 
Name() - Constructor for class alluxio.metrics.MetricKey.Name
 
NAME - Static variable in class alluxio.security.authentication.plain.PlainSaslServerProvider
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigProperty
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.InconsistentProperty
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.ListAllPOptions
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyInfo
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FieldSchema
 
NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.FileFilter
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
NAME_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.NamedAclActions
 
NAMED_GROUP_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclEntryType
NAMED_GROUP = 3;
NAMED_USER_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclEntryType
NAMED_USER = 1;
NamedGroup_VALUE - Static variable in enum alluxio.grpc.PAclEntryType
NamedGroup = 3;
NamedUser_VALUE - Static variable in enum alluxio.grpc.PAclEntryType
NamedUser = 1;
NATIVE_LIB_PATH - Static variable in class alluxio.cli.NativeLibValidationTask
 
NATIVE_LIB_PATH_SEPARATOR - Static variable in class alluxio.cli.NativeLibValidationTask
 
NATIVE_VALUE - Static variable in enum alluxio.grpc.table.TableInfo.TableType
NATIVE = 0;
NativeLibraryLoader - Class in alluxio.jnifuse.utils
This class is used to load the shared library from within the jar.
NativeLibraryLoader.LoadState - Enum in alluxio.jnifuse.utils
 
NativeLibValidationTask - Class in alluxio.cli
Validates the Java native libs defined in the system property.
NativeLibValidationTask() - Constructor for class alluxio.cli.NativeLibValidationTask
Creates a new instance of NativeLibValidationTask for validating Hadoop native lib path.
needContent() - Method in class alluxio.worker.s3.S3NettyBaseTask
Return if the S3 API needs to process the content.
needsCache(URIStatus) - Method in interface alluxio.client.file.cache.filter.CacheFilter
Whether the specific uri needs to be cached or not.
needsCache(URIStatus) - Method in class alluxio.client.file.cache.filter.DefaultCacheFilter
The implementation of needsCache.
needsNormalization(String) - Static method in class alluxio.util.URIUtils
Returns true if the path requires normalization.
needsSync(AlluxioURI) - Method in class alluxio.client.file.DelegatingFileSystem
 
needsSync(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Marks the path in Alluxio as needing sync with the UFS.
needsSync(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Mark a path as needed synchronization with the UFS, when this path or any of its children are accessed, a sync with the UFS will be performed.
needsSync(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
needsSync(AlluxioURI) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
needsSync(NeedsSyncRequest, StreamObserver<NeedsSyncResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
 
needsSync(NeedsSyncRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
 
needsSync(NeedsSyncRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
 
needsSync(NeedsSyncRequest, StreamObserver<NeedsSyncResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
 
needsSync(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
needsSync(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Mark a path as needed synchronization with the UFS, when this path or any of its children are accessed, a sync with the UFS will be performed.
needsSync(NeedsSyncRequest, StreamObserver<NeedsSyncResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
NeedsSyncRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.NeedsSyncRequest
NeedsSyncRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.NeedsSyncRequest
NeedsSyncRequestOrBuilder - Interface in alluxio.grpc
 
NeedsSyncResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.NeedsSyncResponse
NeedsSyncResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.NeedsSyncResponse
NeedsSyncResponseOrBuilder - Interface in alluxio.grpc
 
needVerification() - Method in class alluxio.master.job.CopyJob
Is verification enabled.
needVerification() - Method in class alluxio.master.job.DoraLoadJob
Is verification enabled.
needVerification() - Method in class alluxio.master.job.LoadJob
Is verification enabled.
needVerification() - Method in class alluxio.master.job.MoveJob
Is verification enabled.
needVerification() - Method in interface alluxio.scheduler.job.Job
 
negate() - Method in class alluxio.master.predicate.interval.Interval
 
negate() - Method in class alluxio.master.predicate.interval.IntervalSet
 
NetAddress - Class in alluxio.grpc
Address information about masters.
NetAddress.Builder - Class in alluxio.grpc
Address information about masters.
NetAddressOrBuilder - Interface in alluxio.grpc
 
netAddressToSocketAddress(List<NetAddress>) - Static method in class alluxio.grpc.GrpcUtils
Convert a list of NetAddress to InetSocketAddress.
NETTY_CHANNEL_COUNT - Static variable in class alluxio.metrics.MetricKey
 
NettyBufTargetBuffer - Class in alluxio.file
Netty Buf backed target buffer for zero-copy read from page store.
NettyBufTargetBuffer(ByteBuf) - Constructor for class alluxio.file.NettyBufTargetBuffer
 
NettyChannelPool - Class in alluxio.network.netty
A pool to manage netty channels.
NettyChannelPool(Bootstrap, int, long) - Constructor for class alluxio.network.netty.NettyChannelPool
Creates a netty channel pool instance with a minimum capacity of 1.
NettyClient - Class in alluxio.network.netty
Shared configuration and methods for the Netty client.
NettyDataBuffer - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a ByteBuf.
NettyDataBuffer(ByteBuf) - Constructor for class alluxio.network.protocol.databuffer.NettyDataBuffer
Constructor for creating a NettyDataBuffer, by passing a Netty ByteBuf.
NettyDataReader - Class in alluxio.client.block.stream
A netty packet reader that streams a region from a netty data server.
NettyDataReader - Class in alluxio.client.file.dora.netty
Positioned Netty data reader.
NettyDataReader(FileSystemContext, WorkerNetAddress, Protocol.ReadRequest.Builder) - Constructor for class alluxio.client.file.dora.netty.NettyDataReader
Constructor.
NettyDataReader.Factory - Class in alluxio.client.block.stream
Factory class to create NettyDataReaders.
NettyDataReaderStateMachine - Class in alluxio.client.file.dora.netty
State machine of Netty Client.
NettyDataReaderStateMachine(FileSystemContext, WorkerNetAddress, Protocol.ReadRequest.Builder, ReadTargetBuffer) - Constructor for class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Constructor.
NettyDataReaderStateMachine.TriggerEvent - Enum in alluxio.client.file.dora.netty
Trigger event definition for NettyClientStateMachine.
NettyDataReaderStateMachine.TriggerEventsWithParam - Class in alluxio.client.file.dora.netty
Trigger event with parameters for @{NettyClientStateMacine}.
NettyDataServer - Class in alluxio.worker.netty
Runs a netty data server that responds to block requests.
NettyDataServer(InetSocketAddress, InetSocketAddress, UfsManager, DoraWorker) - Constructor for class alluxio.worker.netty.NettyDataServer
Creates a new instance of NettyDataServer.
NettyDataServer(InetSocketAddress, UfsManager) - Constructor for class alluxio.worker.netty.NettyDataServer
Creates a new instance of NettyDataServer.
NettyDataWriter - Class in alluxio.client.block.stream
A netty packet writer that streams a full block or a UFS file to a netty data server.
NettyDataWriter - Class in alluxio.client.file.dora.netty
A netty packet writer that streams a full block or a UFS file to a netty data server.
NettyDataWriter(FileSystemContext, WorkerNetAddress, long, long, RequestType, OutStreamOptions, Channel) - Constructor for class alluxio.client.file.dora.netty.NettyDataWriter
Creates an instance of NettyDataWriter.
NettyExecutors - Class in alluxio.worker.netty
Adds the block server's pipeline into the channel.
NettyReadHandlerStateMachine<ReqT extends ReadRequest> - Class in alluxio.worker.netty
State machine of Netty Server in Alluxio Worker.
NettyReadHandlerStateMachine(Channel, Class<ReqT>, AbstractReadHandler.PacketReader.Factory<ReqT, ? extends AbstractReadHandler.PacketReader<ReqT>>) - Constructor for class alluxio.worker.netty.NettyReadHandlerStateMachine
The state machine for reading packet task in Alluxio Worker.
NettyRestUtils - Class in alluxio.s3
Utilities for handling S3 REST calls.
NettyRestUtils() - Constructor for class alluxio.s3.NettyRestUtils
 
NettyRestUtils.RestCallable<T> - Interface in alluxio.s3
An interface representing a callable.
NettyRPC - Class in alluxio.network.netty
Netty blocking RPC client.
NettyRPC.RPCHandler - Class in alluxio.network.netty
Netty RPC client handler.
nettyRPCAndLog(Logger, RpcUtils.NettyRPCCallable<T>) - Static method in class alluxio.RpcUtils
Handles a netty RPC callable with logging.
NettyRPCContext - Class in alluxio.network.netty
Context to send a netty RPC.
NettyServerModule - Class in alluxio.worker.modules
Grpc worker module.
NettyServerModule(boolean) - Constructor for class alluxio.worker.modules.NettyServerModule
The constructor of NettyServerModule.
NettyUtils - Class in alluxio.util.network
Utility methods for working with Netty.
NETWORK_CONNECTION_AUTH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_AUTH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_HEALTH_CHECK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_HEALTH_CHECK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_SERVER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_SERVER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_SHUTDOWN_GRACEFUL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_SHUTDOWN_GRACEFUL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_HOST_RESOLUTION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_HOST_RESOLUTION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_IP_ADDRESS_USED - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_IP_ADDRESS_USED - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_NETTY_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_NETTY_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_TLS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_TLS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_TLS_SSL_CONTEXT_PROVIDER_CLASSNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_TLS_SSL_CONTEXT_PROVIDER_CLASSNAME - Static variable in class alluxio.conf.PropertyKey
 
NetworkAddressUtils - Class in alluxio.util.network
Common network address related utilities shared by all components in Alluxio.
NetworkAddressUtils.ServiceAttributeProvider - Interface in alluxio.util.network
An interface to get service attributes.
NetworkAddressUtils.ServiceType - Enum in alluxio.util.network
Different types of services that client uses to connect.
NEVER - Static variable in interface alluxio.master.file.meta.UfsAbsentPathCache
 
NEVER - Static variable in class alluxio.master.predicate.interval.Interval
The interval that is never possible.
NEVER - Static variable in class alluxio.master.predicate.interval.IntervalSet
The interval set that is never possible.
NEVER - Static variable in class alluxio.util.WaitForOptions
 
NEVER_VALUE - Static variable in enum alluxio.grpc.LoadMetadataPType
Never load metadata.
NEW_BLOCK_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
NEW_NAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
NEW_PARENT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
NEW_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
NEW_PATHS_VALUE - Static variable in enum alluxio.grpc.XAttrPropagationStrategy
NEW_PATHS = 1;
newBlock(Supplier<JournalContext>, File.NewBlockEntry) - Method in class alluxio.master.file.meta.InodeTree
 
newBlockingStub(Channel) - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.BlockWorkerGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.MessagingServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.RaftJournalServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBlockingStub(Channel) - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBuilder() - Static method in class alluxio.grpc.ActionInfo
 
newBuilder(ActionInfo) - Static method in class alluxio.grpc.ActionInfo
 
newBuilder() - Static method in class alluxio.grpc.AddPolicyPOptions
 
newBuilder(AddPolicyPOptions) - Static method in class alluxio.grpc.AddPolicyPOptions
 
newBuilder() - Static method in class alluxio.grpc.AddPolicyPRequest
 
newBuilder(AddPolicyPRequest) - Static method in class alluxio.grpc.AddPolicyPRequest
 
newBuilder() - Static method in class alluxio.grpc.AddPolicyPResponse
 
newBuilder(AddPolicyPResponse) - Static method in class alluxio.grpc.AddPolicyPResponse
 
newBuilder() - Static method in class alluxio.grpc.AddQuorumServerRequest
 
newBuilder(AddQuorumServerRequest) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
newBuilder() - Static method in class alluxio.grpc.AsyncCacheRequest
 
newBuilder(AsyncCacheRequest) - Static method in class alluxio.grpc.AsyncCacheRequest
 
newBuilder() - Static method in class alluxio.grpc.AsyncCacheResponse
 
newBuilder(AsyncCacheResponse) - Static method in class alluxio.grpc.AsyncCacheResponse
 
newBuilder() - Static method in class alluxio.grpc.BackupPOptions
 
newBuilder(BackupPOptions) - Static method in class alluxio.grpc.BackupPOptions
 
newBuilder() - Static method in class alluxio.grpc.BackupPRequest
 
newBuilder(BackupPRequest) - Static method in class alluxio.grpc.BackupPRequest
 
newBuilder() - Static method in class alluxio.grpc.BackupPStatus
 
newBuilder(BackupPStatus) - Static method in class alluxio.grpc.BackupPStatus
 
newBuilder() - Static method in class alluxio.grpc.BackupStatusPRequest
 
newBuilder(BackupStatusPRequest) - Static method in class alluxio.grpc.BackupStatusPRequest
 
newBuilder() - Static method in class alluxio.grpc.Block
 
newBuilder(Block) - Static method in class alluxio.grpc.Block
 
newBuilder() - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
newBuilder(BlockHeartbeatPOptions) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
newBuilder() - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
newBuilder(BlockHeartbeatPRequest) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
newBuilder() - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
newBuilder(BlockHeartbeatPResponse) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
newBuilder() - Static method in class alluxio.grpc.BlockIdList
 
newBuilder(BlockIdList) - Static method in class alluxio.grpc.BlockIdList
 
newBuilder() - Static method in class alluxio.grpc.BlockInfo
 
newBuilder(BlockInfo) - Static method in class alluxio.grpc.BlockInfo
 
newBuilder() - Static method in class alluxio.grpc.BlockLocation
 
newBuilder(BlockLocation) - Static method in class alluxio.grpc.BlockLocation
 
newBuilder() - Static method in class alluxio.grpc.BlockMasterInfo
 
newBuilder(BlockMasterInfo) - Static method in class alluxio.grpc.BlockMasterInfo
 
newBuilder() - Static method in class alluxio.grpc.BlockStatus
 
newBuilder(BlockStatus) - Static method in class alluxio.grpc.BlockStatus
 
newBuilder() - Static method in class alluxio.grpc.BlockStoreLocationProto
 
newBuilder(BlockStoreLocationProto) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
newBuilder() - Static method in class alluxio.grpc.BuildVersion
 
newBuilder(BuildVersion) - Static method in class alluxio.grpc.BuildVersion
 
newBuilder() - Static method in class alluxio.grpc.CacheRequest
 
newBuilder(CacheRequest) - Static method in class alluxio.grpc.CacheRequest
 
newBuilder() - Static method in class alluxio.grpc.CacheResponse
 
newBuilder(CacheResponse) - Static method in class alluxio.grpc.CacheResponse
 
newBuilder() - Static method in class alluxio.grpc.CancelPOptions
 
newBuilder(CancelPOptions) - Static method in class alluxio.grpc.CancelPOptions
 
newBuilder() - Static method in class alluxio.grpc.CancelPRequest
 
newBuilder(CancelPRequest) - Static method in class alluxio.grpc.CancelPRequest
 
newBuilder() - Static method in class alluxio.grpc.CancelPResponse
 
newBuilder(CancelPResponse) - Static method in class alluxio.grpc.CancelPResponse
 
newBuilder() - Static method in class alluxio.grpc.CancelTaskCommand
 
newBuilder(CancelTaskCommand) - Static method in class alluxio.grpc.CancelTaskCommand
 
newBuilder() - Static method in class alluxio.grpc.CheckAccessPOptions
 
newBuilder(CheckAccessPOptions) - Static method in class alluxio.grpc.CheckAccessPOptions
 
newBuilder() - Static method in class alluxio.grpc.CheckAccessPRequest
 
newBuilder(CheckAccessPRequest) - Static method in class alluxio.grpc.CheckAccessPRequest
 
newBuilder() - Static method in class alluxio.grpc.CheckAccessPResponse
 
newBuilder(CheckAccessPResponse) - Static method in class alluxio.grpc.CheckAccessPResponse
 
newBuilder() - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
newBuilder(CheckConsistencyPOptions) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
newBuilder() - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
newBuilder(CheckConsistencyPRequest) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
newBuilder() - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
newBuilder(CheckConsistencyPResponse) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
newBuilder() - Static method in class alluxio.grpc.CheckpointPOptions
 
newBuilder(CheckpointPOptions) - Static method in class alluxio.grpc.CheckpointPOptions
 
newBuilder() - Static method in class alluxio.grpc.CheckpointPResponse
 
newBuilder(CheckpointPResponse) - Static method in class alluxio.grpc.CheckpointPResponse
 
newBuilder() - Static method in class alluxio.grpc.CheckRequest
 
newBuilder(CheckRequest) - Static method in class alluxio.grpc.CheckRequest
 
newBuilder() - Static method in class alluxio.grpc.CheckResponse
 
newBuilder(CheckResponse) - Static method in class alluxio.grpc.CheckResponse
 
newBuilder() - Static method in class alluxio.grpc.Chunk
 
newBuilder(Chunk) - Static method in class alluxio.grpc.Chunk
 
newBuilder() - Static method in class alluxio.grpc.ClearMetricsPRequest
 
newBuilder(ClearMetricsPRequest) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
newBuilder() - Static method in class alluxio.grpc.ClearMetricsPResponse
 
newBuilder(ClearMetricsPResponse) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
newBuilder() - Static method in class alluxio.grpc.ClearMetricsRequest
 
newBuilder(ClearMetricsRequest) - Static method in class alluxio.grpc.ClearMetricsRequest
 
newBuilder() - Static method in class alluxio.grpc.ClearMetricsResponse
 
newBuilder(ClearMetricsResponse) - Static method in class alluxio.grpc.ClearMetricsResponse
 
newBuilder() - Static method in class alluxio.grpc.ClientMetrics
 
newBuilder(ClientMetrics) - Static method in class alluxio.grpc.ClientMetrics
 
newBuilder() - Static method in class alluxio.grpc.CmdProgress
 
newBuilder(CmdProgress) - Static method in class alluxio.grpc.CmdProgress
 
newBuilder() - Static method in class alluxio.grpc.CmdStatusBlock
 
newBuilder(CmdStatusBlock) - Static method in class alluxio.grpc.CmdStatusBlock
 
newBuilder() - Static method in class alluxio.grpc.CmdSummary
 
newBuilder(CmdSummary) - Static method in class alluxio.grpc.CmdSummary
 
newBuilder() - Static method in class alluxio.grpc.Command
 
newBuilder(Command) - Static method in class alluxio.grpc.Command
 
newBuilder() - Static method in class alluxio.grpc.CommitBlockPOptions
 
newBuilder(CommitBlockPOptions) - Static method in class alluxio.grpc.CommitBlockPOptions
 
newBuilder() - Static method in class alluxio.grpc.CommitBlockPRequest
 
newBuilder(CommitBlockPRequest) - Static method in class alluxio.grpc.CommitBlockPRequest
 
newBuilder() - Static method in class alluxio.grpc.CommitBlockPResponse
 
newBuilder(CommitBlockPResponse) - Static method in class alluxio.grpc.CommitBlockPResponse
 
newBuilder() - Static method in class alluxio.grpc.CompleteFilePOptions
 
newBuilder(CompleteFilePOptions) - Static method in class alluxio.grpc.CompleteFilePOptions
 
newBuilder() - Static method in class alluxio.grpc.CompleteFilePRequest
 
newBuilder(CompleteFilePRequest) - Static method in class alluxio.grpc.CompleteFilePRequest
 
newBuilder() - Static method in class alluxio.grpc.CompleteFilePResponse
 
newBuilder(CompleteFilePResponse) - Static method in class alluxio.grpc.CompleteFilePResponse
 
newBuilder() - Static method in class alluxio.grpc.ConfigCheckReport
 
newBuilder(ConfigCheckReport) - Static method in class alluxio.grpc.ConfigCheckReport
 
newBuilder() - Static method in class alluxio.grpc.ConfigProperties
 
newBuilder(ConfigProperties) - Static method in class alluxio.grpc.ConfigProperties
 
newBuilder() - Static method in class alluxio.grpc.ConfigProperty
 
newBuilder(ConfigProperty) - Static method in class alluxio.grpc.ConfigProperty
 
newBuilder() - Static method in class alluxio.grpc.CopyJobPOptions
 
newBuilder(CopyJobPOptions) - Static method in class alluxio.grpc.CopyJobPOptions
 
newBuilder() - Static method in class alluxio.grpc.CopyRequest
 
newBuilder(CopyRequest) - Static method in class alluxio.grpc.CopyRequest
 
newBuilder() - Static method in class alluxio.grpc.CopyResponse
 
newBuilder(CopyResponse) - Static method in class alluxio.grpc.CopyResponse
 
newBuilder() - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
newBuilder(CreateDirectoryPOptions) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
newBuilder() - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
newBuilder(CreateDirectoryPRequest) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
newBuilder() - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
newBuilder(CreateDirectoryPResponse) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
newBuilder() - Static method in class alluxio.grpc.CreateFilePOptions
 
newBuilder(CreateFilePOptions) - Static method in class alluxio.grpc.CreateFilePOptions
 
newBuilder() - Static method in class alluxio.grpc.CreateFilePRequest
 
newBuilder(CreateFilePRequest) - Static method in class alluxio.grpc.CreateFilePRequest
 
newBuilder() - Static method in class alluxio.grpc.CreateFilePResponse
 
newBuilder(CreateFilePResponse) - Static method in class alluxio.grpc.CreateFilePResponse
 
newBuilder() - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
newBuilder(DecommissionWorkerPOptions) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
newBuilder() - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
newBuilder(DecommissionWorkerPResponse) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
newBuilder() - Static method in class alluxio.grpc.DeletePOptions
 
newBuilder(DeletePOptions) - Static method in class alluxio.grpc.DeletePOptions
 
newBuilder() - Static method in class alluxio.grpc.DeletePRequest
 
newBuilder(DeletePRequest) - Static method in class alluxio.grpc.DeletePRequest
 
newBuilder() - Static method in class alluxio.grpc.DeletePResponse
 
newBuilder(DeletePResponse) - Static method in class alluxio.grpc.DeletePResponse
 
newBuilder() - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
newBuilder(DownloadSnapshotPRequest) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
newBuilder(DownloadSnapshotPResponse) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.ErrorInfo
 
newBuilder(ErrorInfo) - Static method in class alluxio.grpc.ErrorInfo
 
newBuilder() - Static method in class alluxio.grpc.ExistsPOptions
 
newBuilder(ExistsPOptions) - Static method in class alluxio.grpc.ExistsPOptions
 
newBuilder() - Static method in class alluxio.grpc.ExistsPRequest
 
newBuilder(ExistsPRequest) - Static method in class alluxio.grpc.ExistsPRequest
 
newBuilder() - Static method in class alluxio.grpc.ExistsPResponse
 
newBuilder(ExistsPResponse) - Static method in class alluxio.grpc.ExistsPResponse
 
newBuilder() - Static method in class alluxio.grpc.File
 
newBuilder(File) - Static method in class alluxio.grpc.File
 
newBuilder() - Static method in class alluxio.grpc.FileBlockInfo
 
newBuilder(FileBlockInfo) - Static method in class alluxio.grpc.FileBlockInfo
 
newBuilder() - Static method in class alluxio.grpc.FileFailure
 
newBuilder(FileFailure) - Static method in class alluxio.grpc.FileFailure
 
newBuilder() - Static method in class alluxio.grpc.FileInfo
 
newBuilder(FileInfo) - Static method in class alluxio.grpc.FileInfo
 
newBuilder() - Static method in class alluxio.grpc.FileSystemCommand
 
newBuilder(FileSystemCommand) - Static method in class alluxio.grpc.FileSystemCommand
 
newBuilder() - Static method in class alluxio.grpc.FileSystemCommandOptions
 
newBuilder(FileSystemCommandOptions) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
newBuilder() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
newBuilder(FileSystemHeartbeatPOptions) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
newBuilder() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
newBuilder(FileSystemHeartbeatPRequest) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
newBuilder() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
newBuilder(FileSystemHeartbeatPResponse) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
newBuilder() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
newBuilder(FileSystemMasterCommonPOptions) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
newBuilder() - Static method in class alluxio.grpc.FreePOptions
 
newBuilder(FreePOptions) - Static method in class alluxio.grpc.FreePOptions
 
newBuilder() - Static method in class alluxio.grpc.FreePRequest
 
newBuilder(FreePRequest) - Static method in class alluxio.grpc.FreePRequest
 
newBuilder() - Static method in class alluxio.grpc.FreePResponse
 
newBuilder(FreePResponse) - Static method in class alluxio.grpc.FreePResponse
 
newBuilder() - Static method in class alluxio.grpc.FreeWorkerRequest
 
newBuilder(FreeWorkerRequest) - Static method in class alluxio.grpc.FreeWorkerRequest
 
newBuilder() - Static method in class alluxio.grpc.FreeWorkerResponse
 
newBuilder(FreeWorkerResponse) - Static method in class alluxio.grpc.FreeWorkerResponse
 
newBuilder() - Static method in class alluxio.grpc.FsOpPId
 
newBuilder(FsOpPId) - Static method in class alluxio.grpc.FsOpPId
 
newBuilder() - Static method in class alluxio.grpc.GetActionInfoOptions
 
newBuilder(GetActionInfoOptions) - Static method in class alluxio.grpc.GetActionInfoOptions
 
newBuilder() - Static method in class alluxio.grpc.GetActionInfoRequest
 
newBuilder(GetActionInfoRequest) - Static method in class alluxio.grpc.GetActionInfoRequest
 
newBuilder() - Static method in class alluxio.grpc.GetActionInfoResponse
 
newBuilder(GetActionInfoResponse) - Static method in class alluxio.grpc.GetActionInfoResponse
 
newBuilder() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
newBuilder(GetAllMasterStatusPOptions) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
newBuilder(GetAllMasterStatusPRequest) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
newBuilder(GetAllMasterStatusPResponse) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
newBuilder(GetAllWorkerHealthPOptions) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
newBuilder(GetAllWorkerHealthPRequest) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
newBuilder(GetAllWorkerHealthPResponse) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
newBuilder(GetBlockInfoPOptions) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
newBuilder(GetBlockInfoPRequest) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
newBuilder(GetBlockInfoPResponse) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
newBuilder(GetBlockMasterInfoPOptions) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
newBuilder(GetBlockMasterInfoPResponse) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
newBuilder(GetCapacityBytesPOptions) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
newBuilder(GetCapacityBytesPResponse) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
newBuilder(GetCmdStatusDetailedOptions) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
newBuilder() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
newBuilder(GetCmdStatusDetailedRequest) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
newBuilder() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
newBuilder(GetCmdStatusDetailedResponse) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
newBuilder() - Static method in class alluxio.grpc.GetCmdStatusOptions
 
newBuilder(GetCmdStatusOptions) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
newBuilder() - Static method in class alluxio.grpc.GetCmdStatusRequest
 
newBuilder(GetCmdStatusRequest) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
newBuilder() - Static method in class alluxio.grpc.GetCmdStatusResponse
 
newBuilder(GetCmdStatusResponse) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
newBuilder() - Static method in class alluxio.grpc.GetConfigHashPOptions
 
newBuilder(GetConfigHashPOptions) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetConfigHashPResponse
 
newBuilder(GetConfigHashPResponse) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetConfigReportPOptions
 
newBuilder(GetConfigReportPOptions) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetConfigReportPResponse
 
newBuilder(GetConfigReportPResponse) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetConfigurationPOptions
 
newBuilder(GetConfigurationPOptions) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetConfigurationPResponse
 
newBuilder(GetConfigurationPResponse) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetFileInfoPOptions
 
newBuilder(GetFileInfoPOptions) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetFileInfoPRequest
 
newBuilder(GetFileInfoPRequest) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetFileInfoPResponse
 
newBuilder(GetFileInfoPResponse) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetFilePathPRequest
 
newBuilder(GetFilePathPRequest) - Static method in class alluxio.grpc.GetFilePathPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetFilePathPResponse
 
newBuilder(GetFilePathPResponse) - Static method in class alluxio.grpc.GetFilePathPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
newBuilder(GetJobMasterIdPOptions) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
newBuilder(GetJobMasterIdPRequest) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
newBuilder(GetJobMasterIdPResponse) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetJobProgressPRequest
 
newBuilder(GetJobProgressPRequest) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetJobProgressPResponse
 
newBuilder(GetJobProgressPResponse) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
newBuilder(GetJobServiceSummaryPOptions) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
newBuilder(GetJobServiceSummaryPRequest) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
newBuilder(GetJobServiceSummaryPResponse) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
newBuilder(GetJobStatusDetailedPOptions) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
newBuilder(GetJobStatusDetailedPRequest) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
newBuilder(GetJobStatusDetailedPResponse) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetJobStatusPOptions
 
newBuilder(GetJobStatusPOptions) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetJobStatusPRequest
 
newBuilder(GetJobStatusPRequest) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetJobStatusPResponse
 
newBuilder(GetJobStatusPResponse) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetMasterIdPOptions
 
newBuilder(GetMasterIdPOptions) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetMasterIdPRequest
 
newBuilder(GetMasterIdPRequest) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetMasterIdPResponse
 
newBuilder(GetMasterIdPResponse) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
newBuilder(GetMasterInfoPOptions) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
newBuilder(GetMasterInfoPResponse) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetMetricsPOptions
 
newBuilder(GetMetricsPOptions) - Static method in class alluxio.grpc.GetMetricsPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetMetricsPResponse
 
newBuilder(GetMetricsPResponse) - Static method in class alluxio.grpc.GetMetricsPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetMountIdPRequest
 
newBuilder(GetMountIdPRequest) - Static method in class alluxio.grpc.GetMountIdPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetMountIdPResponse
 
newBuilder(GetMountIdPResponse) - Static method in class alluxio.grpc.GetMountIdPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetMountTablePRequest
 
newBuilder(GetMountTablePRequest) - Static method in class alluxio.grpc.GetMountTablePRequest
 
newBuilder() - Static method in class alluxio.grpc.GetMountTablePResponse
 
newBuilder(GetMountTablePResponse) - Static method in class alluxio.grpc.GetMountTablePResponse
 
newBuilder() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
newBuilder(GetNewBlockIdForFilePOptions) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
newBuilder() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
newBuilder(GetNewBlockIdForFilePRequest) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
newBuilder() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
newBuilder(GetNewBlockIdForFilePResponse) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
newBuilder() - Static method in class alluxio.grpc.GetNodeStatePRequest
 
newBuilder(GetNodeStatePRequest) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
newBuilder() - Static method in class alluxio.grpc.GetNodeStatePResponse
 
newBuilder(GetNodeStatePResponse) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
newBuilder() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
newBuilder(GetPinnedFileIdsPOptions) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
newBuilder(GetPinnedFileIdsPRequest) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
newBuilder(GetPinnedFileIdsPResponse) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
newBuilder(GetPolicyStatusPOptions) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
newBuilder(GetPolicyStatusPRequest) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
newBuilder(GetPolicyStatusPResponse) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
newBuilder(GetQuorumInfoPOptions) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
newBuilder(GetQuorumInfoPRequest) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
newBuilder(GetQuorumInfoPResponse) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
newBuilder(GetRegisterLeasePOptions) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
newBuilder() - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
newBuilder(GetRegisterLeasePRequest) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
newBuilder() - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
newBuilder(GetRegisterLeasePResponse) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
newBuilder() - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
newBuilder(GetServiceVersionPRequest) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
newBuilder(GetServiceVersionPResponse) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
newBuilder(GetSnapshotInfoRequest) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
newBuilder(GetSnapshotInfoResponse) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
newBuilder(GetSnapshotRequest) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
newBuilder(GetStateLockHoldersPOptions) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
newBuilder(GetStateLockHoldersPRequest) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
newBuilder(GetStateLockHoldersPResponse) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetStatusPOptions
 
newBuilder(GetStatusPOptions) - Static method in class alluxio.grpc.GetStatusPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetStatusPRequest
 
newBuilder(GetStatusPRequest) - Static method in class alluxio.grpc.GetStatusPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetStatusPResponse
 
newBuilder(GetStatusPResponse) - Static method in class alluxio.grpc.GetStatusPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
newBuilder(GetTransferLeaderMessageOptions) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
newBuilder() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
newBuilder(GetTransferLeaderMessagePRequest) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
newBuilder() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
newBuilder(GetTransferLeaderMessagePResponse) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
newBuilder() - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
newBuilder(GetUfsInfoPOptions) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
newBuilder(GetUfsInfoPRequest) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
newBuilder(GetUfsInfoPResponse) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
newBuilder(GetUsedBytesPOptions) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
newBuilder(GetUsedBytesPResponse) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
newBuilder(GetWorkerIdPOptions) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
newBuilder(GetWorkerIdPRequest) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
newBuilder(GetWorkerIdPResponse) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
newBuilder(GetWorkerInfoListPOptions) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
newBuilder(GetWorkerInfoListPResponse) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
newBuilder(GetWorkerLostStoragePOptions) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
newBuilder(GetWorkerLostStoragePResponse) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
newBuilder() - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
newBuilder(GetWorkerReportPOptions) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
newBuilder(GrpcServerAddress, AlluxioConfiguration) - Static method in class alluxio.grpc.GrpcChannelBuilder
Create a channel builder for given address using the given configuration.
newBuilder(GrpcServerAddress, AlluxioConfiguration, boolean) - Static method in class alluxio.grpc.GrpcChannelBuilder
Create a channel builder for given address using the given configuration.
newBuilder(GrpcServerAddress, AlluxioConfiguration, AuthType, boolean) - Static method in class alluxio.grpc.GrpcChannelBuilder
Create a channel builder for given address using the given configuration.
newBuilder() - Static method in class alluxio.grpc.InconsistentProperties
 
newBuilder(InconsistentProperties) - Static method in class alluxio.grpc.InconsistentProperties
 
newBuilder() - Static method in class alluxio.grpc.InconsistentProperty
 
newBuilder(InconsistentProperty) - Static method in class alluxio.grpc.InconsistentProperty
 
newBuilder() - Static method in class alluxio.grpc.InconsistentPropertyValues
 
newBuilder(InconsistentPropertyValues) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
newBuilder() - Static method in class alluxio.grpc.JobCommand
 
newBuilder(JobCommand) - Static method in class alluxio.grpc.JobCommand
 
newBuilder() - Static method in class alluxio.grpc.JobDescription
 
newBuilder(JobDescription) - Static method in class alluxio.grpc.JobDescription
 
newBuilder() - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
newBuilder(JobHeartbeatPOptions) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
newBuilder() - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
newBuilder(JobHeartbeatPRequest) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
newBuilder() - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
newBuilder(JobHeartbeatPResponse) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
newBuilder() - Static method in class alluxio.grpc.JobInfo
 
newBuilder(JobInfo) - Static method in class alluxio.grpc.JobInfo
 
newBuilder() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
newBuilder(JobMasterHeartbeatPOptions) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
newBuilder() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
newBuilder(JobMasterHeartbeatPRequest) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
newBuilder() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
newBuilder(JobMasterHeartbeatPResponse) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
newBuilder() - Static method in class alluxio.grpc.JobMasterStatus
 
newBuilder(JobMasterStatus) - Static method in class alluxio.grpc.JobMasterStatus
 
newBuilder() - Static method in class alluxio.grpc.JobProgress
 
newBuilder(JobProgress) - Static method in class alluxio.grpc.JobProgress
 
newBuilder() - Static method in class alluxio.grpc.JobProgressPOptions
 
newBuilder(JobProgressPOptions) - Static method in class alluxio.grpc.JobProgressPOptions
 
newBuilder() - Static method in class alluxio.grpc.JobServiceSummary
 
newBuilder(JobServiceSummary) - Static method in class alluxio.grpc.JobServiceSummary
 
newBuilder() - Static method in class alluxio.grpc.JobStatusBlock
 
newBuilder(JobStatusBlock) - Static method in class alluxio.grpc.JobStatusBlock
 
newBuilder() - Static method in class alluxio.grpc.JobUnused
 
newBuilder(JobUnused) - Static method in class alluxio.grpc.JobUnused
 
newBuilder() - Static method in class alluxio.grpc.JobWorkerHealth
 
newBuilder(JobWorkerHealth) - Static method in class alluxio.grpc.JobWorkerHealth
 
newBuilder() - Static method in class alluxio.grpc.JournalQueryRequest
 
newBuilder(JournalQueryRequest) - Static method in class alluxio.grpc.JournalQueryRequest
 
newBuilder() - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
newBuilder(JournalQueryResponse) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
newBuilder(LatestSnapshotInfoPRequest) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
newBuilder() - Static method in class alluxio.grpc.ListAllPOptions
 
newBuilder(ListAllPOptions) - Static method in class alluxio.grpc.ListAllPOptions
 
newBuilder() - Static method in class alluxio.grpc.ListAllPRequest
 
newBuilder(ListAllPRequest) - Static method in class alluxio.grpc.ListAllPRequest
 
newBuilder() - Static method in class alluxio.grpc.ListAllPResponse
 
newBuilder(ListAllPResponse) - Static method in class alluxio.grpc.ListAllPResponse
 
newBuilder() - Static method in class alluxio.grpc.ListPolicyPOptions
 
newBuilder(ListPolicyPOptions) - Static method in class alluxio.grpc.ListPolicyPOptions
 
newBuilder() - Static method in class alluxio.grpc.ListPolicyPRequest
 
newBuilder(ListPolicyPRequest) - Static method in class alluxio.grpc.ListPolicyPRequest
 
newBuilder() - Static method in class alluxio.grpc.ListPolicyPResponse
 
newBuilder(ListPolicyPResponse) - Static method in class alluxio.grpc.ListPolicyPResponse
 
newBuilder() - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
newBuilder(ListProxyStatusPOptions) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
newBuilder() - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
newBuilder(ListProxyStatusPRequest) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
newBuilder() - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
newBuilder(ListProxyStatusPResponse) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
newBuilder() - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
newBuilder(ListStatusPartialPOptions) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
newBuilder() - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
newBuilder(ListStatusPartialPRequest) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
newBuilder() - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
newBuilder(ListStatusPartialPResponse) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
newBuilder() - Static method in class alluxio.grpc.ListStatusPOptions
 
newBuilder(ListStatusPOptions) - Static method in class alluxio.grpc.ListStatusPOptions
 
newBuilder() - Static method in class alluxio.grpc.ListStatusPRequest
 
newBuilder(ListStatusPRequest) - Static method in class alluxio.grpc.ListStatusPRequest
 
newBuilder() - Static method in class alluxio.grpc.ListStatusPResponse
 
newBuilder(ListStatusPResponse) - Static method in class alluxio.grpc.ListStatusPResponse
 
newBuilder() - Static method in class alluxio.grpc.LoadFileFailure
 
newBuilder(LoadFileFailure) - Static method in class alluxio.grpc.LoadFileFailure
 
newBuilder() - Static method in class alluxio.grpc.LoadFileRequest
 
newBuilder(LoadFileRequest) - Static method in class alluxio.grpc.LoadFileRequest
 
newBuilder() - Static method in class alluxio.grpc.LoadFileResponse
 
newBuilder(LoadFileResponse) - Static method in class alluxio.grpc.LoadFileResponse
 
newBuilder() - Static method in class alluxio.grpc.LoadJobPOptions
 
newBuilder(LoadJobPOptions) - Static method in class alluxio.grpc.LoadJobPOptions
 
newBuilder() - Static method in class alluxio.grpc.LoadMetadataPOptions
 
newBuilder(LoadMetadataPOptions) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
newBuilder() - Static method in class alluxio.grpc.LoadRequest
 
newBuilder(LoadRequest) - Static method in class alluxio.grpc.LoadRequest
 
newBuilder() - Static method in class alluxio.grpc.LoadResponse
 
newBuilder(LoadResponse) - Static method in class alluxio.grpc.LoadResponse
 
newBuilder() - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
newBuilder(LocationBlockIdListEntry) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
newBuilder() - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
newBuilder(MasterHeartbeatPOptions) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
newBuilder() - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
newBuilder(MasterHeartbeatPRequest) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
newBuilder() - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
newBuilder(MasterHeartbeatPResponse) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
newBuilder() - Static method in class alluxio.grpc.MasterInfo
 
newBuilder(MasterInfo) - Static method in class alluxio.grpc.MasterInfo
 
newBuilder() - Static method in class alluxio.grpc.MasterVersion
 
newBuilder(MasterVersion) - Static method in class alluxio.grpc.MasterVersion
 
newBuilder() - Static method in class alluxio.grpc.MessagingRequestHeader
 
newBuilder(MessagingRequestHeader) - Static method in class alluxio.grpc.MessagingRequestHeader
 
newBuilder() - Static method in class alluxio.grpc.MessagingResponseHeader
 
newBuilder(MessagingResponseHeader) - Static method in class alluxio.grpc.MessagingResponseHeader
 
newBuilder() - Static method in class alluxio.grpc.Metric
 
newBuilder(Metric) - Static method in class alluxio.grpc.Metric
 
newBuilder() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
newBuilder(MetricsHeartbeatPOptions) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
newBuilder() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
newBuilder(MetricsHeartbeatPRequest) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
newBuilder() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
newBuilder(MetricsHeartbeatPResponse) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
newBuilder() - Static method in class alluxio.grpc.MetricValue
 
newBuilder(MetricValue) - Static method in class alluxio.grpc.MetricValue
 
newBuilder() - Static method in class alluxio.grpc.MountPointInfo
 
newBuilder(MountPointInfo) - Static method in class alluxio.grpc.MountPointInfo
 
newBuilder() - Static method in class alluxio.grpc.MountPOptions
 
newBuilder(MountPOptions) - Static method in class alluxio.grpc.MountPOptions
 
newBuilder() - Static method in class alluxio.grpc.MountPRequest
 
newBuilder(MountPRequest) - Static method in class alluxio.grpc.MountPRequest
 
newBuilder() - Static method in class alluxio.grpc.MountPResponse
 
newBuilder(MountPResponse) - Static method in class alluxio.grpc.MountPResponse
 
newBuilder() - Static method in class alluxio.grpc.MoveBlockRequest
 
newBuilder(MoveBlockRequest) - Static method in class alluxio.grpc.MoveBlockRequest
 
newBuilder() - Static method in class alluxio.grpc.MoveBlockResponse
 
newBuilder(MoveBlockResponse) - Static method in class alluxio.grpc.MoveBlockResponse
 
newBuilder() - Static method in class alluxio.grpc.MoveJobPOptions
 
newBuilder(MoveJobPOptions) - Static method in class alluxio.grpc.MoveJobPOptions
 
newBuilder() - Static method in class alluxio.grpc.MoveRequest
 
newBuilder(MoveRequest) - Static method in class alluxio.grpc.MoveRequest
 
newBuilder() - Static method in class alluxio.grpc.MoveResponse
 
newBuilder(MoveResponse) - Static method in class alluxio.grpc.MoveResponse
 
newBuilder() - Static method in class alluxio.grpc.NeedsSyncRequest
 
newBuilder(NeedsSyncRequest) - Static method in class alluxio.grpc.NeedsSyncRequest
 
newBuilder() - Static method in class alluxio.grpc.NeedsSyncResponse
 
newBuilder(NeedsSyncResponse) - Static method in class alluxio.grpc.NeedsSyncResponse
 
newBuilder() - Static method in class alluxio.grpc.NetAddress
 
newBuilder(NetAddress) - Static method in class alluxio.grpc.NetAddress
 
newBuilder() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
newBuilder(NotifyWorkerIdPOptions) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
newBuilder() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
newBuilder(NotifyWorkerIdPRequest) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
newBuilder() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
newBuilder(NotifyWorkerIdPResponse) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
newBuilder() - Static method in class alluxio.grpc.OpenFilePOptions
 
newBuilder(OpenFilePOptions) - Static method in class alluxio.grpc.OpenFilePOptions
 
newBuilder() - Static method in class alluxio.grpc.PAcl
 
newBuilder(PAcl) - Static method in class alluxio.grpc.PAcl
 
newBuilder() - Static method in class alluxio.grpc.PAclEntry
 
newBuilder(PAclEntry) - Static method in class alluxio.grpc.PAclEntry
 
newBuilder() - Static method in class alluxio.grpc.PersistCommandOptions
 
newBuilder(PersistCommandOptions) - Static method in class alluxio.grpc.PersistCommandOptions
 
newBuilder() - Static method in class alluxio.grpc.PersistFile
 
newBuilder(PersistFile) - Static method in class alluxio.grpc.PersistFile
 
newBuilder() - Static method in class alluxio.grpc.PMode
 
newBuilder(PMode) - Static method in class alluxio.grpc.PMode
 
newBuilder() - Static method in class alluxio.grpc.PolicyInfo
 
newBuilder(PolicyInfo) - Static method in class alluxio.grpc.PolicyInfo
 
newBuilder() - Static method in class alluxio.grpc.PolicyStatus
 
newBuilder(PolicyStatus) - Static method in class alluxio.grpc.PolicyStatus
 
newBuilder() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
newBuilder(ProxyHeartbeatPOptions) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
newBuilder() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
newBuilder(ProxyHeartbeatPRequest) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
newBuilder() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
newBuilder(ProxyHeartbeatPResponse) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
newBuilder() - Static method in class alluxio.grpc.ProxyStatus
 
newBuilder(ProxyStatus) - Static method in class alluxio.grpc.ProxyStatus
 
newBuilder() - Static method in class alluxio.grpc.QuorumServerInfo
 
newBuilder(QuorumServerInfo) - Static method in class alluxio.grpc.QuorumServerInfo
 
newBuilder() - Static method in class alluxio.grpc.ReadRequest
 
newBuilder(ReadRequest) - Static method in class alluxio.grpc.ReadRequest
 
newBuilder() - Static method in class alluxio.grpc.ReadResponse
 
newBuilder(ReadResponse) - Static method in class alluxio.grpc.ReadResponse
 
newBuilder() - Static method in class alluxio.grpc.RegisterCommand
 
newBuilder(RegisterCommand) - Static method in class alluxio.grpc.RegisterCommand
 
newBuilder() - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
newBuilder(RegisterJobMasterPOptions) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
newBuilder() - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
newBuilder(RegisterJobMasterPRequest) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
newBuilder() - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
newBuilder(RegisterJobMasterPResponse) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
newBuilder() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
newBuilder(RegisterJobWorkerPOptions) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
newBuilder() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
newBuilder(RegisterJobWorkerPRequest) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
newBuilder() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
newBuilder(RegisterJobWorkerPResponse) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
newBuilder() - Static method in class alluxio.grpc.RegisterMasterPOptions
 
newBuilder(RegisterMasterPOptions) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
newBuilder() - Static method in class alluxio.grpc.RegisterMasterPRequest
 
newBuilder(RegisterMasterPRequest) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
newBuilder() - Static method in class alluxio.grpc.RegisterMasterPResponse
 
newBuilder(RegisterMasterPResponse) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
newBuilder() - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
newBuilder(RegisterWorkerPOptions) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
newBuilder() - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
newBuilder(RegisterWorkerPRequest) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
newBuilder() - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
newBuilder(RegisterWorkerPResponse) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
newBuilder() - Static method in class alluxio.grpc.RemoveBlockRequest
 
newBuilder(RemoveBlockRequest) - Static method in class alluxio.grpc.RemoveBlockRequest
 
newBuilder() - Static method in class alluxio.grpc.RemoveBlockResponse
 
newBuilder(RemoveBlockResponse) - Static method in class alluxio.grpc.RemoveBlockResponse
 
newBuilder() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
newBuilder(RemoveDisabledWorkerPOptions) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
newBuilder() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
newBuilder(RemoveDisabledWorkerPResponse) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
newBuilder() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
newBuilder(RemovePathConfigurationPOptions) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
newBuilder() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
newBuilder(RemovePathConfigurationPRequest) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
newBuilder() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
newBuilder(RemovePathConfigurationPResponse) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
newBuilder() - Static method in class alluxio.grpc.RemovePolicyPOptions
 
newBuilder(RemovePolicyPOptions) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
newBuilder() - Static method in class alluxio.grpc.RemovePolicyPRequest
 
newBuilder(RemovePolicyPRequest) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
newBuilder() - Static method in class alluxio.grpc.RemovePolicyPResponse
 
newBuilder(RemovePolicyPResponse) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
newBuilder() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
newBuilder(RemoveQuorumServerPOptions) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
newBuilder() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
newBuilder(RemoveQuorumServerPRequest) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
newBuilder() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
newBuilder(RemoveQuorumServerPResponse) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
newBuilder() - Static method in class alluxio.grpc.RenamePOptions
 
newBuilder(RenamePOptions) - Static method in class alluxio.grpc.RenamePOptions
 
newBuilder() - Static method in class alluxio.grpc.RenamePRequest
 
newBuilder(RenamePRequest) - Static method in class alluxio.grpc.RenamePRequest
 
newBuilder() - Static method in class alluxio.grpc.RenamePResponse
 
newBuilder(RenamePResponse) - Static method in class alluxio.grpc.RenamePResponse
 
newBuilder() - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
newBuilder(ResetPrioritiesPOptions) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
newBuilder() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
newBuilder(ResetPrioritiesPRequest) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
newBuilder() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
newBuilder(ResetPrioritiesPResponse) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
newBuilder() - Static method in class alluxio.grpc.RetryInfo
 
newBuilder(RetryInfo) - Static method in class alluxio.grpc.RetryInfo
 
newBuilder() - Static method in class alluxio.grpc.ReverseResolvePRequest
 
newBuilder(ReverseResolvePRequest) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
newBuilder() - Static method in class alluxio.grpc.ReverseResolvePResponse
 
newBuilder(ReverseResolvePResponse) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
newBuilder() - Static method in class alluxio.grpc.Route
 
newBuilder(Route) - Static method in class alluxio.grpc.Route
 
newBuilder() - Static method in class alluxio.grpc.RouteFailure
 
newBuilder(RouteFailure) - Static method in class alluxio.grpc.RouteFailure
 
newBuilder() - Static method in class alluxio.grpc.RunPOptions
 
newBuilder(RunPOptions) - Static method in class alluxio.grpc.RunPOptions
 
newBuilder() - Static method in class alluxio.grpc.RunPRequest
 
newBuilder(RunPRequest) - Static method in class alluxio.grpc.RunPRequest
 
newBuilder() - Static method in class alluxio.grpc.RunPResponse
 
newBuilder(RunPResponse) - Static method in class alluxio.grpc.RunPResponse
 
newBuilder() - Static method in class alluxio.grpc.RunTaskCommand
 
newBuilder(RunTaskCommand) - Static method in class alluxio.grpc.RunTaskCommand
 
newBuilder() - Static method in class alluxio.grpc.S3SyntaxOptions
 
newBuilder(S3SyntaxOptions) - Static method in class alluxio.grpc.S3SyntaxOptions
 
newBuilder() - Static method in class alluxio.grpc.SaslMessage
 
newBuilder(SaslMessage) - Static method in class alluxio.grpc.SaslMessage
 
newBuilder() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
newBuilder(ScheduleAsyncPersistencePOptions) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
newBuilder() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
newBuilder(ScheduleAsyncPersistencePRequest) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
newBuilder() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
newBuilder(ScheduleAsyncPersistencePResponse) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
newBuilder() - Static method in class alluxio.grpc.SetAclPOptions
 
newBuilder(SetAclPOptions) - Static method in class alluxio.grpc.SetAclPOptions
 
newBuilder() - Static method in class alluxio.grpc.SetAclPRequest
 
newBuilder(SetAclPRequest) - Static method in class alluxio.grpc.SetAclPRequest
 
newBuilder() - Static method in class alluxio.grpc.SetAclPResponse
 
newBuilder(SetAclPResponse) - Static method in class alluxio.grpc.SetAclPResponse
 
newBuilder() - Static method in class alluxio.grpc.SetAttributePOptions
 
newBuilder(SetAttributePOptions) - Static method in class alluxio.grpc.SetAttributePOptions
 
newBuilder() - Static method in class alluxio.grpc.SetAttributePRequest
 
newBuilder(SetAttributePRequest) - Static method in class alluxio.grpc.SetAttributePRequest
 
newBuilder() - Static method in class alluxio.grpc.SetAttributePResponse
 
newBuilder(SetAttributePResponse) - Static method in class alluxio.grpc.SetAttributePResponse
 
newBuilder() - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
newBuilder(SetPathConfigurationPOptions) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
newBuilder() - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
newBuilder(SetPathConfigurationPRequest) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
newBuilder() - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
newBuilder(SetPathConfigurationPResponse) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
newBuilder() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
newBuilder(SetTaskPoolSizeCommand) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
newBuilder() - Static method in class alluxio.grpc.SnapshotData
 
newBuilder(SnapshotData) - Static method in class alluxio.grpc.SnapshotData
 
newBuilder() - Static method in class alluxio.grpc.SnapshotMetadata
 
newBuilder(SnapshotMetadata) - Static method in class alluxio.grpc.SnapshotMetadata
 
newBuilder() - Static method in class alluxio.grpc.StatusSummary
 
newBuilder(StatusSummary) - Static method in class alluxio.grpc.StatusSummary
 
newBuilder() - Static method in class alluxio.grpc.StopJobPRequest
 
newBuilder(StopJobPRequest) - Static method in class alluxio.grpc.StopJobPRequest
 
newBuilder() - Static method in class alluxio.grpc.StopJobPResponse
 
newBuilder(StopJobPResponse) - Static method in class alluxio.grpc.StopJobPResponse
 
newBuilder() - Static method in class alluxio.grpc.StorageList
 
newBuilder(StorageList) - Static method in class alluxio.grpc.StorageList
 
newBuilder() - Static method in class alluxio.grpc.SubmitJobPRequest
 
newBuilder(SubmitJobPRequest) - Static method in class alluxio.grpc.SubmitJobPRequest
 
newBuilder() - Static method in class alluxio.grpc.SubmitJobPResponse
 
newBuilder(SubmitJobPResponse) - Static method in class alluxio.grpc.SubmitJobPResponse
 
newBuilder() - Static method in class alluxio.grpc.SubmitOptions
 
newBuilder(SubmitOptions) - Static method in class alluxio.grpc.SubmitOptions
 
newBuilder() - Static method in class alluxio.grpc.SubmitRequest
 
newBuilder(SubmitRequest) - Static method in class alluxio.grpc.SubmitRequest
 
newBuilder() - Static method in class alluxio.grpc.SubmitResponse
 
newBuilder(SubmitResponse) - Static method in class alluxio.grpc.SubmitResponse
 
newBuilder() - Static method in class alluxio.grpc.table.AllOrNoneSet
 
newBuilder(AllOrNoneSet) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
newBuilder() - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
newBuilder(AttachDatabasePRequest) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
newBuilder() - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
newBuilder(AttachDatabasePResponse) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
newBuilder() - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
newBuilder(BinaryColumnStatsData) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
newBuilder() - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
newBuilder(BooleanColumnStatsData) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
newBuilder() - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
newBuilder(ColumnStatisticsData) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
newBuilder() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
newBuilder(ColumnStatisticsInfo) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
newBuilder() - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
newBuilder(ColumnStatisticsList) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
newBuilder() - Static method in class alluxio.grpc.table.Constraint
 
newBuilder(Constraint) - Static method in class alluxio.grpc.table.Constraint
 
newBuilder() - Static method in class alluxio.grpc.table.Database
 
newBuilder(Database) - Static method in class alluxio.grpc.table.Database
 
newBuilder() - Static method in class alluxio.grpc.table.Date
 
newBuilder(Date) - Static method in class alluxio.grpc.table.Date
 
newBuilder() - Static method in class alluxio.grpc.table.DateColumnStatsData
 
newBuilder(DateColumnStatsData) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
newBuilder() - Static method in class alluxio.grpc.table.Decimal
 
newBuilder(Decimal) - Static method in class alluxio.grpc.table.Decimal
 
newBuilder() - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
newBuilder(DecimalColumnStatsData) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
newBuilder() - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
newBuilder(DetachDatabasePRequest) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
newBuilder() - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
newBuilder(DetachDatabasePResponse) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
newBuilder() - Static method in class alluxio.grpc.table.Domain
 
newBuilder(Domain) - Static method in class alluxio.grpc.table.Domain
 
newBuilder() - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
newBuilder(DoubleColumnStatsData) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
newBuilder() - Static method in class alluxio.grpc.table.EquatableValueSet
 
newBuilder(EquatableValueSet) - Static method in class alluxio.grpc.table.EquatableValueSet
 
newBuilder() - Static method in class alluxio.grpc.table.FieldSchema
 
newBuilder(FieldSchema) - Static method in class alluxio.grpc.table.FieldSchema
 
newBuilder() - Static method in class alluxio.grpc.table.FileStatistics
 
newBuilder(FileStatistics) - Static method in class alluxio.grpc.table.FileStatistics
 
newBuilder() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
newBuilder(GetAllDatabasesPRequest) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
newBuilder() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
newBuilder(GetAllDatabasesPResponse) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
newBuilder() - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
newBuilder(GetAllTablesPRequest) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
newBuilder() - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
newBuilder(GetAllTablesPResponse) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
newBuilder() - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
newBuilder(GetDatabasePRequest) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
newBuilder() - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
newBuilder(GetDatabasePResponse) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
newBuilder() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
newBuilder(GetPartitionColumnStatisticsPRequest) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
newBuilder() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
newBuilder(GetPartitionColumnStatisticsPResponse) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
newBuilder() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
newBuilder(GetTableColumnStatisticsPRequest) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
newBuilder() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
newBuilder(GetTableColumnStatisticsPResponse) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
newBuilder() - Static method in class alluxio.grpc.table.GetTablePRequest
 
newBuilder(GetTablePRequest) - Static method in class alluxio.grpc.table.GetTablePRequest
 
newBuilder() - Static method in class alluxio.grpc.table.GetTablePResponse
 
newBuilder(GetTablePResponse) - Static method in class alluxio.grpc.table.GetTablePResponse
 
newBuilder() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
newBuilder(GetTransformJobInfoPRequest) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
newBuilder() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
newBuilder(GetTransformJobInfoPResponse) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
newBuilder() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
newBuilder(HiveBucketProperty) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
newBuilder() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
newBuilder(PartitionInfo) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
newBuilder() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
newBuilder(SortingColumn) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
newBuilder() - Static method in class alluxio.grpc.table.layout.hive.Storage
 
newBuilder(Storage) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
newBuilder() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
newBuilder(StorageFormat) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
newBuilder() - Static method in class alluxio.grpc.table.Layout
 
newBuilder(Layout) - Static method in class alluxio.grpc.table.Layout
 
newBuilder() - Static method in class alluxio.grpc.table.LayoutSpec
 
newBuilder(LayoutSpec) - Static method in class alluxio.grpc.table.LayoutSpec
 
newBuilder() - Static method in class alluxio.grpc.table.LongColumnStatsData
 
newBuilder(LongColumnStatsData) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
newBuilder() - Static method in class alluxio.grpc.table.Partition
 
newBuilder(Partition) - Static method in class alluxio.grpc.table.Partition
 
newBuilder() - Static method in class alluxio.grpc.table.PartitionSpec
 
newBuilder(PartitionSpec) - Static method in class alluxio.grpc.table.PartitionSpec
 
newBuilder() - Static method in class alluxio.grpc.table.Range
 
newBuilder(Range) - Static method in class alluxio.grpc.table.Range
 
newBuilder() - Static method in class alluxio.grpc.table.RangeSet
 
newBuilder(RangeSet) - Static method in class alluxio.grpc.table.RangeSet
 
newBuilder() - Static method in class alluxio.grpc.table.ReadTablePRequest
 
newBuilder(ReadTablePRequest) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
newBuilder() - Static method in class alluxio.grpc.table.ReadTablePResponse
 
newBuilder(ReadTablePResponse) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
newBuilder() - Static method in class alluxio.grpc.table.Schema
 
newBuilder(Schema) - Static method in class alluxio.grpc.table.Schema
 
newBuilder() - Static method in class alluxio.grpc.table.StringColumnStatsData
 
newBuilder(StringColumnStatsData) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
newBuilder() - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
newBuilder(SyncDatabasePRequest) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
newBuilder() - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
newBuilder(SyncDatabasePResponse) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
newBuilder() - Static method in class alluxio.grpc.table.SyncStatus
 
newBuilder(SyncStatus) - Static method in class alluxio.grpc.table.SyncStatus
 
newBuilder() - Static method in class alluxio.grpc.table.TableInfo
 
newBuilder(TableInfo) - Static method in class alluxio.grpc.table.TableInfo
 
newBuilder() - Static method in class alluxio.grpc.table.Transformation
 
newBuilder(Transformation) - Static method in class alluxio.grpc.table.Transformation
 
newBuilder() - Static method in class alluxio.grpc.table.TransformJobInfo
 
newBuilder(TransformJobInfo) - Static method in class alluxio.grpc.table.TransformJobInfo
 
newBuilder() - Static method in class alluxio.grpc.table.TransformTablePRequest
 
newBuilder(TransformTablePRequest) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
newBuilder() - Static method in class alluxio.grpc.table.TransformTablePResponse
 
newBuilder(TransformTablePResponse) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
newBuilder() - Static method in class alluxio.grpc.table.Value
 
newBuilder(Value) - Static method in class alluxio.grpc.table.Value
 
newBuilder() - Static method in class alluxio.grpc.TierList
 
newBuilder(TierList) - Static method in class alluxio.grpc.TierList
 
newBuilder() - Static method in class alluxio.grpc.TransferLeaderMessage
 
newBuilder(TransferLeaderMessage) - Static method in class alluxio.grpc.TransferLeaderMessage
 
newBuilder() - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
newBuilder(TransferLeadershipPOptions) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
newBuilder() - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
newBuilder(TransferLeadershipPRequest) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
newBuilder() - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
newBuilder(TransferLeadershipPResponse) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
newBuilder() - Static method in class alluxio.grpc.TransportMessage
 
newBuilder(TransportMessage) - Static method in class alluxio.grpc.TransportMessage
 
newBuilder() - Static method in class alluxio.grpc.TriggerPolicyRequest
 
newBuilder(TriggerPolicyRequest) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
newBuilder() - Static method in class alluxio.grpc.TriggerPolicyResponse
 
newBuilder(TriggerPolicyResponse) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
newBuilder() - Static method in class alluxio.grpc.UfsFileStatus
 
newBuilder(UfsFileStatus) - Static method in class alluxio.grpc.UfsFileStatus
 
newBuilder() - Static method in class alluxio.grpc.UfsInfo
 
newBuilder(UfsInfo) - Static method in class alluxio.grpc.UfsInfo
 
newBuilder() - Static method in class alluxio.grpc.UfsReadOptions
 
newBuilder(UfsReadOptions) - Static method in class alluxio.grpc.UfsReadOptions
 
newBuilder() - Static method in class alluxio.grpc.UfsStatus
 
newBuilder(UfsStatus) - Static method in class alluxio.grpc.UfsStatus
 
newBuilder() - Static method in class alluxio.grpc.UnmountPOptions
 
newBuilder(UnmountPOptions) - Static method in class alluxio.grpc.UnmountPOptions
 
newBuilder() - Static method in class alluxio.grpc.UnmountPRequest
 
newBuilder(UnmountPRequest) - Static method in class alluxio.grpc.UnmountPRequest
 
newBuilder() - Static method in class alluxio.grpc.UnmountPResponse
 
newBuilder(UnmountPResponse) - Static method in class alluxio.grpc.UnmountPResponse
 
newBuilder() - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
newBuilder(UpdateConfigurationPRequest) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
newBuilder() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
newBuilder(UpdateConfigurationPResponse) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
newBuilder() - Static method in class alluxio.grpc.UpdateMountPRequest
 
newBuilder(UpdateMountPRequest) - Static method in class alluxio.grpc.UpdateMountPRequest
 
newBuilder() - Static method in class alluxio.grpc.UpdateMountPResponse
 
newBuilder(UpdateMountPResponse) - Static method in class alluxio.grpc.UpdateMountPResponse
 
newBuilder() - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
newBuilder(UpdateUfsModePOptions) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
newBuilder() - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
newBuilder(UpdateUfsModePRequest) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
newBuilder() - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
newBuilder(UpdateUfsModePResponse) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
newBuilder() - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
newBuilder(UploadSnapshotPRequest) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
newBuilder(UploadSnapshotPResponse) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
newBuilder() - Static method in class alluxio.grpc.WorkerIdentity
 
newBuilder(WorkerIdentity) - Static method in class alluxio.grpc.WorkerIdentity
 
newBuilder() - Static method in class alluxio.grpc.WorkerInfo
 
newBuilder(WorkerInfo) - Static method in class alluxio.grpc.WorkerInfo
 
newBuilder() - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
newBuilder(WorkerLostStorageInfo) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
newBuilder() - Static method in class alluxio.grpc.WorkerNetAddress
 
newBuilder(WorkerNetAddress) - Static method in class alluxio.grpc.WorkerNetAddress
 
newBuilder() - Static method in class alluxio.grpc.WriteOptions
 
newBuilder(WriteOptions) - Static method in class alluxio.grpc.WriteOptions
 
newBuilder() - Static method in class alluxio.grpc.WriteRequest
 
newBuilder(WriteRequest) - Static method in class alluxio.grpc.WriteRequest
 
newBuilder() - Static method in class alluxio.grpc.WriteRequestCommand
 
newBuilder(WriteRequestCommand) - Static method in class alluxio.grpc.WriteRequestCommand
 
newBuilder() - Static method in class alluxio.grpc.WriteResponse
 
newBuilder(WriteResponse) - Static method in class alluxio.grpc.WriteResponse
 
newBuilder() - Static method in class alluxio.job.JobDescription
 
newBuilder() - Static method in class alluxio.master.CoreMasterContext
 
newBuilder(ClientContext) - Static method in class alluxio.master.MasterClientContext
Create an instance of a MasterClientContextBuilder which can be used to obtain and instance of MasterClientContext.
newBuilder() - Static method in class alluxio.master.metastore.caching.CacheConfiguration
 
newBuilder() - Static method in class alluxio.master.metastore.ReadOption
 
newBuilder(List<PortCoordination.ReservedPort>) - Static method in class alluxio.multi.process.MultiProcessCluster
 
newBuilder() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
newBuilder(Cache.PPageStoreCommonOptions) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
newBuilder() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
newBuilder(Cache.PRocksPageStoreOptions) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilder(Protocol.AsyncCacheRequest) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilder(Protocol.CreateUfsFileOptions) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilder(Protocol.Heartbeat) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilder(Protocol.LocalBlockCloseRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilder(Protocol.LocalBlockCompleteRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilder(Protocol.LocalBlockCreateRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilder(Protocol.LocalBlockCreateResponse) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilder(Protocol.LocalBlockOpenRequest) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilder(Protocol.LocalBlockOpenResponse) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilder(Protocol.OpenUfsBlockOptions) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilder(Protocol.ReadRequest) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilder(Protocol.ReadResponse) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilder(Protocol.Response) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilder() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilder(Protocol.WriteRequest) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilder() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilder(Block.BlockContainerIdGeneratorEntry) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilder(Block.BlockInfoEntry) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilder(Block.DeleteBlockEntry) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
newBuilder(File.ActiveSyncTxIdEntry) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilder(File.AddMountPointEntry) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
newBuilder(File.AddSyncPointEntry) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilder(File.AsyncPersistRequestEntry) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilder(File.CompleteFileEntry) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilder(File.DeleteFileEntry) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilder(File.DeleteMountPointEntry) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilder(File.InodeDirectoryEntry) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilder(File.InodeDirectoryIdGeneratorEntry) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilder(File.InodeFileEntry) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilder(File.InodeLastModificationTimeEntry) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
newBuilder(File.NewBlockEntry) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilder(File.PersistDirectoryEntry) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilder(File.PersistFileEntry) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
newBuilder(File.RemoveSyncPointEntry) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.RenameEntry
 
newBuilder(File.RenameEntry) - Static method in class alluxio.proto.journal.File.RenameEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.SetAclEntry
 
newBuilder(File.SetAclEntry) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilder(File.SetAttributeEntry) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilder(File.StringPairEntry) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
newBuilder(File.UpdateInodeDirectoryEntry) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
newBuilder(File.UpdateInodeEntry) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
newBuilder(File.UpdateInodeFileEntry) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
newBuilder() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilder(File.UpdateUfsModeEntry) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
newBuilder(Job.CopyJobEntry) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Job.FileFilter
 
newBuilder(Job.FileFilter) - Static method in class alluxio.proto.journal.Job.FileFilter
 
newBuilder() - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
newBuilder(Job.LoadJobEntry) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
newBuilder(Job.MoveJobEntry) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilder(Journal.JournalEntry) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
newBuilder(Journal.JournalOpPId) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
newBuilder() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
newBuilder(Meta.ClusterInfoEntry) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
newBuilder(Meta.PathPropertiesEntry) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
newBuilder(Meta.RemovePathPropertiesEntry) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
newBuilder(Policy.PolicyDefinitionEntry) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
newBuilder() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
newBuilder(Policy.PolicyRemoveEntry) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
newBuilder() - Static method in class alluxio.proto.meta.Block.BlockLocation
 
newBuilder(Block.BlockLocation) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
newBuilder() - Static method in class alluxio.proto.meta.Block.BlockMeta
 
newBuilder(Block.BlockMeta) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
newBuilder() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
newBuilder(DoraMeta.FileStatus) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
newBuilder() - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
newBuilder(InodeMeta.Inode) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
newBuilder() - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
newBuilder(Acl.AccessControlList) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
newBuilder() - Static method in class alluxio.proto.shared.Acl.AclActions
 
newBuilder(Acl.AclActions) - Static method in class alluxio.proto.shared.Acl.AclActions
 
newBuilder() - Static method in class alluxio.proto.shared.Acl.AclEntry
 
newBuilder(Acl.AclEntry) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
newBuilder() - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
newBuilder(Acl.NamedAclActions) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
newBuilder() - Static method in class alluxio.wire.Configuration
 
newBuilder(ClientContext) - Static method in class alluxio.worker.job.JobMasterClientContext
Create a builder for JobMasterClientContext.
newBuilderForType() - Method in class alluxio.grpc.ActionInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ActionInfo
 
newBuilderForType() - Method in class alluxio.grpc.AddPolicyPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.AddPolicyPOptions
 
newBuilderForType() - Method in class alluxio.grpc.AddPolicyPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.AddPolicyPRequest
 
newBuilderForType() - Method in class alluxio.grpc.AddPolicyPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.AddPolicyPResponse
 
newBuilderForType() - Method in class alluxio.grpc.AddQuorumServerRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.AddQuorumServerRequest
 
newBuilderForType() - Method in class alluxio.grpc.AsyncCacheRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.AsyncCacheRequest
 
newBuilderForType() - Method in class alluxio.grpc.AsyncCacheResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.AsyncCacheResponse
 
newBuilderForType() - Method in class alluxio.grpc.BackupPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BackupPOptions
 
newBuilderForType() - Method in class alluxio.grpc.BackupPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BackupPRequest
 
newBuilderForType() - Method in class alluxio.grpc.BackupPStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BackupPStatus
 
newBuilderForType() - Method in class alluxio.grpc.BackupStatusPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BackupStatusPRequest
 
newBuilderForType() - Method in class alluxio.grpc.Block
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.Block
 
newBuilderForType() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
newBuilderForType() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
newBuilderForType() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
newBuilderForType() - Method in class alluxio.grpc.BlockIdList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockIdList
 
newBuilderForType() - Method in class alluxio.grpc.BlockInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockInfo
 
newBuilderForType() - Method in class alluxio.grpc.BlockLocation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockLocation
 
newBuilderForType() - Method in class alluxio.grpc.BlockMasterInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockMasterInfo
 
newBuilderForType() - Method in class alluxio.grpc.BlockStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockStatus
 
newBuilderForType() - Method in class alluxio.grpc.BlockStoreLocationProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BlockStoreLocationProto
 
newBuilderForType() - Method in class alluxio.grpc.BuildVersion
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.BuildVersion
 
newBuilderForType() - Method in class alluxio.grpc.CacheRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CacheRequest
 
newBuilderForType() - Method in class alluxio.grpc.CacheResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CacheResponse
 
newBuilderForType() - Method in class alluxio.grpc.CancelPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CancelPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CancelPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CancelPRequest
 
newBuilderForType() - Method in class alluxio.grpc.CancelPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CancelPResponse
 
newBuilderForType() - Method in class alluxio.grpc.CancelTaskCommand
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CancelTaskCommand
 
newBuilderForType() - Method in class alluxio.grpc.CheckAccessPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckAccessPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CheckAccessPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckAccessPRequest
 
newBuilderForType() - Method in class alluxio.grpc.CheckAccessPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckAccessPResponse
 
newBuilderForType() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckConsistencyPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckConsistencyPRequest
 
newBuilderForType() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckConsistencyPResponse
 
newBuilderForType() - Method in class alluxio.grpc.CheckpointPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckpointPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CheckpointPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckpointPResponse
 
newBuilderForType() - Method in class alluxio.grpc.CheckRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckRequest
 
newBuilderForType() - Method in class alluxio.grpc.CheckResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CheckResponse
 
newBuilderForType() - Method in class alluxio.grpc.Chunk
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.Chunk
 
newBuilderForType() - Method in class alluxio.grpc.ClearMetricsPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ClearMetricsPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ClearMetricsPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ClearMetricsPResponse
 
newBuilderForType() - Method in class alluxio.grpc.ClearMetricsRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ClearMetricsRequest
 
newBuilderForType() - Method in class alluxio.grpc.ClearMetricsResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ClearMetricsResponse
 
newBuilderForType() - Method in class alluxio.grpc.ClientMetrics
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ClientMetrics
 
newBuilderForType() - Method in class alluxio.grpc.CmdProgress
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CmdProgress
 
newBuilderForType() - Method in class alluxio.grpc.CmdStatusBlock
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CmdStatusBlock
 
newBuilderForType() - Method in class alluxio.grpc.CmdSummary
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CmdSummary
 
newBuilderForType() - Method in class alluxio.grpc.Command
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.Command
 
newBuilderForType() - Method in class alluxio.grpc.CommitBlockPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CommitBlockPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CommitBlockPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CommitBlockPRequest
 
newBuilderForType() - Method in class alluxio.grpc.CommitBlockPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CommitBlockPResponse
 
newBuilderForType() - Method in class alluxio.grpc.CompleteFilePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CompleteFilePOptions
 
newBuilderForType() - Method in class alluxio.grpc.CompleteFilePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CompleteFilePRequest
 
newBuilderForType() - Method in class alluxio.grpc.CompleteFilePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CompleteFilePResponse
 
newBuilderForType() - Method in class alluxio.grpc.ConfigCheckReport
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ConfigCheckReport
 
newBuilderForType() - Method in class alluxio.grpc.ConfigProperties
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ConfigProperties
 
newBuilderForType() - Method in class alluxio.grpc.ConfigProperty
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ConfigProperty
 
newBuilderForType() - Method in class alluxio.grpc.CopyJobPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CopyJobPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CopyRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CopyRequest
 
newBuilderForType() - Method in class alluxio.grpc.CopyResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CopyResponse
 
newBuilderForType() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateDirectoryPOptions
 
newBuilderForType() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateDirectoryPRequest
 
newBuilderForType() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateDirectoryPResponse
 
newBuilderForType() - Method in class alluxio.grpc.CreateFilePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateFilePOptions
 
newBuilderForType() - Method in class alluxio.grpc.CreateFilePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateFilePRequest
 
newBuilderForType() - Method in class alluxio.grpc.CreateFilePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.CreateFilePResponse
 
newBuilderForType() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
newBuilderForType() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
newBuilderForType() - Method in class alluxio.grpc.DeletePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.DeletePOptions
 
newBuilderForType() - Method in class alluxio.grpc.DeletePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.DeletePRequest
 
newBuilderForType() - Method in class alluxio.grpc.DeletePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.DeletePResponse
 
newBuilderForType() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.ErrorInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ErrorInfo
 
newBuilderForType() - Method in class alluxio.grpc.ExistsPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ExistsPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ExistsPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ExistsPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ExistsPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ExistsPResponse
 
newBuilderForType() - Method in class alluxio.grpc.File
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.File
 
newBuilderForType() - Method in class alluxio.grpc.FileBlockInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileBlockInfo
 
newBuilderForType() - Method in class alluxio.grpc.FileFailure
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileFailure
 
newBuilderForType() - Method in class alluxio.grpc.FileInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileInfo
 
newBuilderForType() - Method in class alluxio.grpc.FileSystemCommand
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileSystemCommand
 
newBuilderForType() - Method in class alluxio.grpc.FileSystemCommandOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileSystemCommandOptions
 
newBuilderForType() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
newBuilderForType() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
newBuilderForType() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
newBuilderForType() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
newBuilderForType() - Method in class alluxio.grpc.FreePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FreePOptions
 
newBuilderForType() - Method in class alluxio.grpc.FreePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FreePRequest
 
newBuilderForType() - Method in class alluxio.grpc.FreePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FreePResponse
 
newBuilderForType() - Method in class alluxio.grpc.FreeWorkerRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FreeWorkerRequest
 
newBuilderForType() - Method in class alluxio.grpc.FreeWorkerResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FreeWorkerResponse
 
newBuilderForType() - Method in class alluxio.grpc.FsOpPId
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.FsOpPId
 
newBuilderForType() - Method in class alluxio.grpc.GetActionInfoOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetActionInfoOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetActionInfoRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetActionInfoRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetActionInfoResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetActionInfoResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetBlockInfoPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetBlockInfoPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetBlockInfoPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetCmdStatusOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCmdStatusOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetCmdStatusRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCmdStatusRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetCmdStatusResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetCmdStatusResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetConfigHashPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetConfigHashPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetConfigHashPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetConfigHashPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetConfigReportPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetConfigReportPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetConfigReportPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetConfigReportPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetConfigurationPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetConfigurationPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetConfigurationPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetConfigurationPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetFileInfoPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetFileInfoPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetFileInfoPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetFileInfoPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetFileInfoPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetFileInfoPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetFilePathPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetFilePathPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetFilePathPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetFilePathPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetJobProgressPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobProgressPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetJobProgressPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobProgressPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetJobStatusPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobStatusPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetJobStatusPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobStatusPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetJobStatusPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetJobStatusPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetMasterIdPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMasterIdPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetMasterIdPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMasterIdPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetMasterIdPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMasterIdPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMasterInfoPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMasterInfoPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetMetricsPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMetricsPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetMetricsPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMetricsPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetMountIdPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMountIdPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetMountIdPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMountIdPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetMountTablePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMountTablePRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetMountTablePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetMountTablePResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetNodeStatePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetNodeStatePRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetNodeStatePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetNodeStatePResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetServiceVersionPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetServiceVersionPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetStatusPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetStatusPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetStatusPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetStatusPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetStatusPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetStatusPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetUfsInfoPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetUfsInfoPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetUfsInfoPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetUsedBytesPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetUsedBytesPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerIdPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerIdPRequest
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerIdPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
newBuilderForType() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.GetWorkerReportPOptions
 
newBuilderForType() - Method in class alluxio.grpc.InconsistentProperties
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.InconsistentProperties
 
newBuilderForType() - Method in class alluxio.grpc.InconsistentProperty
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.InconsistentProperty
 
newBuilderForType() - Method in class alluxio.grpc.InconsistentPropertyValues
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.InconsistentPropertyValues
 
newBuilderForType() - Method in class alluxio.grpc.JobCommand
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobCommand
 
newBuilderForType() - Method in class alluxio.grpc.JobDescription
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobDescription
 
newBuilderForType() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobHeartbeatPOptions
 
newBuilderForType() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobHeartbeatPRequest
 
newBuilderForType() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobHeartbeatPResponse
 
newBuilderForType() - Method in class alluxio.grpc.JobInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobInfo
 
newBuilderForType() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
newBuilderForType() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
newBuilderForType() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
newBuilderForType() - Method in class alluxio.grpc.JobMasterStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobMasterStatus
 
newBuilderForType() - Method in class alluxio.grpc.JobProgress
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobProgress
 
newBuilderForType() - Method in class alluxio.grpc.JobProgressPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobProgressPOptions
 
newBuilderForType() - Method in class alluxio.grpc.JobServiceSummary
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobServiceSummary
 
newBuilderForType() - Method in class alluxio.grpc.JobStatusBlock
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobStatusBlock
 
newBuilderForType() - Method in class alluxio.grpc.JobUnused
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobUnused
 
newBuilderForType() - Method in class alluxio.grpc.JobWorkerHealth
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JobWorkerHealth
 
newBuilderForType() - Method in class alluxio.grpc.JournalQueryRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JournalQueryRequest
 
newBuilderForType() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ListAllPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListAllPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ListAllPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListAllPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ListAllPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListAllPResponse
 
newBuilderForType() - Method in class alluxio.grpc.ListPolicyPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListPolicyPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ListPolicyPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListPolicyPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ListPolicyPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListPolicyPResponse
 
newBuilderForType() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListProxyStatusPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListProxyStatusPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListProxyStatusPResponse
 
newBuilderForType() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListStatusPartialPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListStatusPartialPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListStatusPartialPResponse
 
newBuilderForType() - Method in class alluxio.grpc.ListStatusPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListStatusPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ListStatusPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListStatusPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ListStatusPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ListStatusPResponse
 
newBuilderForType() - Method in class alluxio.grpc.LoadFileFailure
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadFileFailure
 
newBuilderForType() - Method in class alluxio.grpc.LoadFileRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadFileRequest
 
newBuilderForType() - Method in class alluxio.grpc.LoadFileResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadFileResponse
 
newBuilderForType() - Method in class alluxio.grpc.LoadJobPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadJobPOptions
 
newBuilderForType() - Method in class alluxio.grpc.LoadMetadataPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadMetadataPOptions
 
newBuilderForType() - Method in class alluxio.grpc.LoadRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadRequest
 
newBuilderForType() - Method in class alluxio.grpc.LoadResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LoadResponse
 
newBuilderForType() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.LocationBlockIdListEntry
 
newBuilderForType() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
newBuilderForType() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
newBuilderForType() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
newBuilderForType() - Method in class alluxio.grpc.MasterInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MasterInfo
 
newBuilderForType() - Method in class alluxio.grpc.MasterVersion
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MasterVersion
 
newBuilderForType() - Method in class alluxio.grpc.MessagingRequestHeader
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MessagingRequestHeader
 
newBuilderForType() - Method in class alluxio.grpc.MessagingResponseHeader
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MessagingResponseHeader
 
newBuilderForType() - Method in class alluxio.grpc.Metric
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.Metric
 
newBuilderForType() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
newBuilderForType() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
newBuilderForType() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
newBuilderForType() - Method in class alluxio.grpc.MetricValue
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MetricValue
 
newBuilderForType() - Method in class alluxio.grpc.MountPointInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MountPointInfo
 
newBuilderForType() - Method in class alluxio.grpc.MountPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MountPOptions
 
newBuilderForType() - Method in class alluxio.grpc.MountPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MountPRequest
 
newBuilderForType() - Method in class alluxio.grpc.MountPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MountPResponse
 
newBuilderForType() - Method in class alluxio.grpc.MoveBlockRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MoveBlockRequest
 
newBuilderForType() - Method in class alluxio.grpc.MoveBlockResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MoveBlockResponse
 
newBuilderForType() - Method in class alluxio.grpc.MoveJobPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MoveJobPOptions
 
newBuilderForType() - Method in class alluxio.grpc.MoveRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MoveRequest
 
newBuilderForType() - Method in class alluxio.grpc.MoveResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.MoveResponse
 
newBuilderForType() - Method in class alluxio.grpc.NeedsSyncRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.NeedsSyncRequest
 
newBuilderForType() - Method in class alluxio.grpc.NeedsSyncResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.NeedsSyncResponse
 
newBuilderForType() - Method in class alluxio.grpc.NetAddress
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.NetAddress
 
newBuilderForType() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
newBuilderForType() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
newBuilderForType() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
newBuilderForType() - Method in class alluxio.grpc.OpenFilePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.OpenFilePOptions
 
newBuilderForType() - Method in class alluxio.grpc.PAcl
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.PAcl
 
newBuilderForType() - Method in class alluxio.grpc.PAclEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.PAclEntry
 
newBuilderForType() - Method in class alluxio.grpc.PersistCommandOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.PersistCommandOptions
 
newBuilderForType() - Method in class alluxio.grpc.PersistFile
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.PersistFile
 
newBuilderForType() - Method in class alluxio.grpc.PMode
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.PMode
 
newBuilderForType() - Method in class alluxio.grpc.PolicyInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.PolicyInfo
 
newBuilderForType() - Method in class alluxio.grpc.PolicyStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.PolicyStatus
 
newBuilderForType() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
newBuilderForType() - Method in class alluxio.grpc.ProxyStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ProxyStatus
 
newBuilderForType() - Method in class alluxio.grpc.QuorumServerInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.QuorumServerInfo
 
newBuilderForType() - Method in class alluxio.grpc.ReadRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ReadRequest
 
newBuilderForType() - Method in class alluxio.grpc.ReadResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ReadResponse
 
newBuilderForType() - Method in class alluxio.grpc.RegisterCommand
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterCommand
 
newBuilderForType() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RegisterMasterPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterMasterPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RegisterMasterPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterMasterPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RegisterMasterPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterMasterPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterWorkerPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterWorkerPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RegisterWorkerPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RemoveBlockRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemoveBlockRequest
 
newBuilderForType() - Method in class alluxio.grpc.RemoveBlockResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemoveBlockResponse
 
newBuilderForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RemovePolicyPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemovePolicyPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RemovePolicyPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemovePolicyPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RemovePolicyPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemovePolicyPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RenamePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RenamePOptions
 
newBuilderForType() - Method in class alluxio.grpc.RenamePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RenamePRequest
 
newBuilderForType() - Method in class alluxio.grpc.RenamePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RenamePResponse
 
newBuilderForType() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
newBuilderForType() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
newBuilderForType() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RetryInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RetryInfo
 
newBuilderForType() - Method in class alluxio.grpc.ReverseResolvePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ReverseResolvePRequest
 
newBuilderForType() - Method in class alluxio.grpc.ReverseResolvePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ReverseResolvePResponse
 
newBuilderForType() - Method in class alluxio.grpc.Route
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.Route
 
newBuilderForType() - Method in class alluxio.grpc.RouteFailure
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RouteFailure
 
newBuilderForType() - Method in class alluxio.grpc.RunPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RunPOptions
 
newBuilderForType() - Method in class alluxio.grpc.RunPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RunPRequest
 
newBuilderForType() - Method in class alluxio.grpc.RunPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RunPResponse
 
newBuilderForType() - Method in class alluxio.grpc.RunTaskCommand
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.RunTaskCommand
 
newBuilderForType() - Method in class alluxio.grpc.S3SyntaxOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.S3SyntaxOptions
 
newBuilderForType() - Method in class alluxio.grpc.SaslMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SaslMessage
 
newBuilderForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
newBuilderForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
newBuilderForType() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
newBuilderForType() - Method in class alluxio.grpc.SetAclPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetAclPOptions
 
newBuilderForType() - Method in class alluxio.grpc.SetAclPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetAclPRequest
 
newBuilderForType() - Method in class alluxio.grpc.SetAclPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetAclPResponse
 
newBuilderForType() - Method in class alluxio.grpc.SetAttributePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetAttributePOptions
 
newBuilderForType() - Method in class alluxio.grpc.SetAttributePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetAttributePRequest
 
newBuilderForType() - Method in class alluxio.grpc.SetAttributePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetAttributePResponse
 
newBuilderForType() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
newBuilderForType() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
newBuilderForType() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
newBuilderForType() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
newBuilderForType() - Method in class alluxio.grpc.SnapshotData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SnapshotData
 
newBuilderForType() - Method in class alluxio.grpc.SnapshotMetadata
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SnapshotMetadata
 
newBuilderForType() - Method in class alluxio.grpc.StatusSummary
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StatusSummary
 
newBuilderForType() - Method in class alluxio.grpc.StopJobPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StopJobPRequest
 
newBuilderForType() - Method in class alluxio.grpc.StopJobPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StopJobPResponse
 
newBuilderForType() - Method in class alluxio.grpc.StorageList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.StorageList
 
newBuilderForType() - Method in class alluxio.grpc.SubmitJobPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SubmitJobPRequest
 
newBuilderForType() - Method in class alluxio.grpc.SubmitJobPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SubmitJobPResponse
 
newBuilderForType() - Method in class alluxio.grpc.SubmitOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SubmitOptions
 
newBuilderForType() - Method in class alluxio.grpc.SubmitRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SubmitRequest
 
newBuilderForType() - Method in class alluxio.grpc.SubmitResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.SubmitResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.AllOrNoneSet
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.AllOrNoneSet
 
newBuilderForType() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
newBuilderForType() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
newBuilderForType() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.ColumnStatisticsData
 
newBuilderForType() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
newBuilderForType() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.ColumnStatisticsList
 
newBuilderForType() - Method in class alluxio.grpc.table.Constraint
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Constraint
 
newBuilderForType() - Method in class alluxio.grpc.table.Database
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Database
 
newBuilderForType() - Method in class alluxio.grpc.table.Date
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Date
 
newBuilderForType() - Method in class alluxio.grpc.table.DateColumnStatsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.DateColumnStatsData
 
newBuilderForType() - Method in class alluxio.grpc.table.Decimal
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Decimal
 
newBuilderForType() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
newBuilderForType() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.Domain
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Domain
 
newBuilderForType() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
newBuilderForType() - Method in class alluxio.grpc.table.EquatableValueSet
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.EquatableValueSet
 
newBuilderForType() - Method in class alluxio.grpc.table.FieldSchema
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.FieldSchema
 
newBuilderForType() - Method in class alluxio.grpc.table.FileStatistics
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.FileStatistics
 
newBuilderForType() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetDatabasePRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetDatabasePResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.GetTablePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetTablePRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.GetTablePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetTablePResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
newBuilderForType() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
newBuilderForType() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
newBuilderForType() - Method in class alluxio.grpc.table.layout.hive.Storage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.layout.hive.Storage
 
newBuilderForType() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
newBuilderForType() - Method in class alluxio.grpc.table.Layout
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Layout
 
newBuilderForType() - Method in class alluxio.grpc.table.LayoutSpec
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.LayoutSpec
 
newBuilderForType() - Method in class alluxio.grpc.table.LongColumnStatsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.LongColumnStatsData
 
newBuilderForType() - Method in class alluxio.grpc.table.Partition
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Partition
 
newBuilderForType() - Method in class alluxio.grpc.table.PartitionSpec
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.PartitionSpec
 
newBuilderForType() - Method in class alluxio.grpc.table.Range
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Range
 
newBuilderForType() - Method in class alluxio.grpc.table.RangeSet
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.RangeSet
 
newBuilderForType() - Method in class alluxio.grpc.table.ReadTablePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.ReadTablePRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.ReadTablePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.ReadTablePResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.Schema
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Schema
 
newBuilderForType() - Method in class alluxio.grpc.table.StringColumnStatsData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.StringColumnStatsData
 
newBuilderForType() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.SyncStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.SyncStatus
 
newBuilderForType() - Method in class alluxio.grpc.table.TableInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.TableInfo
 
newBuilderForType() - Method in class alluxio.grpc.table.Transformation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Transformation
 
newBuilderForType() - Method in class alluxio.grpc.table.TransformJobInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.TransformJobInfo
 
newBuilderForType() - Method in class alluxio.grpc.table.TransformTablePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.TransformTablePRequest
 
newBuilderForType() - Method in class alluxio.grpc.table.TransformTablePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.TransformTablePResponse
 
newBuilderForType() - Method in class alluxio.grpc.table.Value
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.table.Value
 
newBuilderForType() - Method in class alluxio.grpc.TierList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TierList
 
newBuilderForType() - Method in class alluxio.grpc.TransferLeaderMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TransferLeaderMessage
 
newBuilderForType() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TransferLeadershipPOptions
 
newBuilderForType() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TransferLeadershipPRequest
 
newBuilderForType() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TransferLeadershipPResponse
 
newBuilderForType() - Method in class alluxio.grpc.TransportMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TransportMessage
 
newBuilderForType() - Method in class alluxio.grpc.TriggerPolicyRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TriggerPolicyRequest
 
newBuilderForType() - Method in class alluxio.grpc.TriggerPolicyResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.TriggerPolicyResponse
 
newBuilderForType() - Method in class alluxio.grpc.UfsFileStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UfsFileStatus
 
newBuilderForType() - Method in class alluxio.grpc.UfsInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UfsInfo
 
newBuilderForType() - Method in class alluxio.grpc.UfsReadOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UfsReadOptions
 
newBuilderForType() - Method in class alluxio.grpc.UfsStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UfsStatus
 
newBuilderForType() - Method in class alluxio.grpc.UnmountPOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UnmountPOptions
 
newBuilderForType() - Method in class alluxio.grpc.UnmountPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UnmountPRequest
 
newBuilderForType() - Method in class alluxio.grpc.UnmountPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UnmountPResponse
 
newBuilderForType() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
newBuilderForType() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
newBuilderForType() - Method in class alluxio.grpc.UpdateMountPRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UpdateMountPRequest
 
newBuilderForType() - Method in class alluxio.grpc.UpdateMountPResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UpdateMountPResponse
 
newBuilderForType() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UpdateUfsModePOptions
 
newBuilderForType() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UpdateUfsModePRequest
 
newBuilderForType() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UpdateUfsModePResponse
 
newBuilderForType() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
newBuilderForType() - Method in class alluxio.grpc.WorkerIdentity
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WorkerIdentity
 
newBuilderForType() - Method in class alluxio.grpc.WorkerInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WorkerInfo
 
newBuilderForType() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WorkerLostStorageInfo
 
newBuilderForType() - Method in class alluxio.grpc.WorkerNetAddress
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WorkerNetAddress
 
newBuilderForType() - Method in class alluxio.grpc.WriteOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WriteOptions
 
newBuilderForType() - Method in class alluxio.grpc.WriteRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WriteRequest
 
newBuilderForType() - Method in class alluxio.grpc.WriteRequestCommand
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WriteRequestCommand
 
newBuilderForType() - Method in class alluxio.grpc.WriteResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.grpc.WriteResponse
 
newBuilderForType() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
newBuilderForType() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.Response
 
newBuilderForType() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newBuilderForType() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.InodeFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.NewBlockEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.PersistFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.RenameEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.RenameEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.SetAclEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.SetAclEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.StringPairEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Job.FileFilter
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Job.FileFilter
 
newBuilderForType() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Journal.JournalEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
newBuilderForType() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
newBuilderForType() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
newBuilderForType() - Method in class alluxio.proto.meta.Block.BlockLocation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.meta.Block.BlockLocation
 
newBuilderForType() - Method in class alluxio.proto.meta.Block.BlockMeta
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.meta.Block.BlockMeta
 
newBuilderForType() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
newBuilderForType() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.meta.InodeMeta.Inode
 
newBuilderForType() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.shared.Acl.AccessControlList
 
newBuilderForType() - Method in class alluxio.proto.shared.Acl.AclActions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.shared.Acl.AclActions
 
newBuilderForType() - Method in class alluxio.proto.shared.Acl.AclEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.shared.Acl.AclEntry
 
newBuilderForType() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
newByteArrayFromByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Creates a byte array from the given ByteBuffer, the position property of input ByteBuffer remains unchanged.
newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class alluxio.grpc.GrpcChannel
 
newCondition() - Method in class alluxio.master.block.meta.WorkerMetaLock
 
newFutureStub(Channel) - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.BlockWorkerGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.MessagingServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.RaftJournalServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newFutureStub(Channel) - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newIncompleteFuture() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new incomplete CompletableFuture of the type to be returned by a CompletionStage method.
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ActionInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.AddPolicyPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.AddPolicyPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.AddPolicyPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.AddQuorumServerRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.AsyncCacheRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.AsyncCacheResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BackupPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BackupPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BackupPStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BackupStatusPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.Block
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockIdList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockLocation
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockMasterInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BlockStoreLocationProto
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.BuildVersion
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CacheRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CacheResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CancelPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CancelPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CancelPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CancelTaskCommand
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckAccessPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckAccessPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckAccessPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckConsistencyPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckConsistencyPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckConsistencyPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckpointPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckpointPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CheckResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.Chunk
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ClearMetricsPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ClearMetricsPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ClearMetricsRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ClearMetricsResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ClientMetrics
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CmdProgress
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CmdStatusBlock
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CmdSummary
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.Command
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CommitBlockPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CommitBlockPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CommitBlockPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CompleteFilePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CompleteFilePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CompleteFilePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ConfigCheckReport
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ConfigProperties
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ConfigProperty
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CopyJobPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CopyRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CopyResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CreateDirectoryPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CreateDirectoryPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CreateDirectoryPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CreateFilePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CreateFilePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.CreateFilePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.DeletePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.DeletePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.DeletePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ErrorInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ExistsPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ExistsPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ExistsPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.File
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileBlockInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileFailure
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileSystemCommand
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileSystemCommandOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FreePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FreePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FreePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FreeWorkerRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FreeWorkerResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.FsOpPId
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetActionInfoOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetActionInfoRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetActionInfoResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetBlockInfoPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetBlockInfoPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetBlockInfoPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCmdStatusOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCmdStatusRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetCmdStatusResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetConfigHashPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetConfigHashPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetConfigReportPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetConfigReportPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetConfigurationPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetConfigurationPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetFileInfoPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetFileInfoPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetFileInfoPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetFilePathPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetFilePathPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobProgressPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobProgressPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobStatusPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobStatusPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetJobStatusPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMasterIdPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMasterIdPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMasterIdPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMasterInfoPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMasterInfoPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMetricsPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMetricsPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMountIdPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMountIdPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMountTablePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetMountTablePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetNodeStatePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetNodeStatePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetServiceVersionPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetServiceVersionPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetStatusPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetStatusPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetStatusPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetUfsInfoPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetUfsInfoPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetUfsInfoPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetUsedBytesPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetUsedBytesPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerIdPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerIdPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerIdPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.GetWorkerReportPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.InconsistentProperties
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.InconsistentProperty
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.InconsistentPropertyValues
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobCommand
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobDescription
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobHeartbeatPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobHeartbeatPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobHeartbeatPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobMasterStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobProgress
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobProgressPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobServiceSummary
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobStatusBlock
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobUnused
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JobWorkerHealth
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JournalQueryRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListAllPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListAllPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListAllPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListPolicyPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListPolicyPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListPolicyPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListProxyStatusPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListProxyStatusPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListProxyStatusPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListStatusPartialPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListStatusPartialPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListStatusPartialPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListStatusPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListStatusPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ListStatusPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LoadFileFailure
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LoadFileRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LoadFileResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LoadJobPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LoadMetadataPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LoadRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LoadResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.LocationBlockIdListEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MasterInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MasterVersion
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MessagingRequestHeader
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MessagingResponseHeader
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.Metric
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MetricValue
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MountPointInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MountPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MountPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MountPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MoveBlockRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MoveBlockResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MoveJobPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MoveRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.MoveResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.NeedsSyncRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.NeedsSyncResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.NetAddress
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.OpenFilePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.PAcl
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.PAclEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.PersistCommandOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.PersistFile
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.PMode
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.PolicyInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.PolicyStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ProxyStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.QuorumServerInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ReadRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ReadResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterCommand
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterMasterPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterMasterPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterMasterPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterWorkerPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterWorkerPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RegisterWorkerPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemoveBlockRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemoveBlockResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemovePolicyPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemovePolicyPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemovePolicyPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RenamePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RenamePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RenamePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RetryInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ReverseResolvePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ReverseResolvePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.Route
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RouteFailure
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RunPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RunPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RunPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.RunTaskCommand
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.S3SyntaxOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SaslMessage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetAclPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetAclPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetAclPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetAttributePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetAttributePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetAttributePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SnapshotData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SnapshotMetadata
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StatusSummary
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StopJobPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StopJobPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.StorageList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SubmitJobPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SubmitJobPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SubmitOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SubmitRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.SubmitResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.AllOrNoneSet
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.ColumnStatisticsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.ColumnStatisticsList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Constraint
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Database
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Date
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.DateColumnStatsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Decimal
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Domain
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.EquatableValueSet
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.FieldSchema
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.FileStatistics
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetDatabasePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetDatabasePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetTablePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetTablePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.layout.hive.Storage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Layout
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.LayoutSpec
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.LongColumnStatsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Partition
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.PartitionSpec
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Range
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.RangeSet
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.ReadTablePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.ReadTablePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Schema
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.StringColumnStatsData
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.SyncStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.TableInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Transformation
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.TransformJobInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.TransformTablePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.TransformTablePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.table.Value
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TierList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TransferLeaderMessage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TransferLeadershipPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TransferLeadershipPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TransferLeadershipPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TransportMessage
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TriggerPolicyRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.TriggerPolicyResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UfsFileStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UfsInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UfsReadOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UfsStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UnmountPOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UnmountPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UnmountPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UpdateMountPRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UpdateMountPResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UpdateUfsModePOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UpdateUfsModePRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UpdateUfsModePResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WorkerIdentity
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WorkerInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WorkerLostStorageInfo
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WorkerNetAddress
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WriteOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WriteRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WriteRequestCommand
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.grpc.WriteResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.Response
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.InodeFileEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.NewBlockEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.PersistFileEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.RenameEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.SetAclEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.StringPairEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Job.FileFilter
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Journal.JournalEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.meta.Block.BlockLocation
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.meta.Block.BlockMeta
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.meta.InodeMeta.Inode
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.shared.Acl.AccessControlList
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.shared.Acl.AclActions
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.shared.Acl.AclEntry
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
newResourceLeakDetector(Class<T>, int, long) - Method in class alluxio.resource.AlluxioResourceLeakDetectorFactory
 
newResourceLeakDetector(Class<T>, int) - Method in class alluxio.resource.AlluxioResourceLeakDetectorFactory
 
newStub(Channel) - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.BlockWorkerGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.MessagingServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.RaftJournalServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
Creates a new async stub that supports all call types for the service
newStub(Channel) - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
Creates a new async stub that supports all call types for the service
newTaskFor(Runnable, T) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
newTaskFor(Callable<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
newThread(ForkJoinPool) - Method in class alluxio.concurrent.jsr.ForkJoinPool.AlluxioForkJoinWorkerThreadFactory
 
newThread(ForkJoinPool) - Method in interface alluxio.concurrent.jsr.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
newThread(Runnable) - Method in class alluxio.master.transport.GrpcMessagingThreadFactory
 
next() - Method in class alluxio.job.workflow.WorkflowExecution
Given the previous set of jobs were completed successfully, returns a list of jobs to execute next.
next() - Method in class alluxio.master.file.meta.InodeTreeBufferedIterator
 
next() - Method in class alluxio.master.job.FileIterable.FileIterator
 
next() - Method in interface alluxio.master.journal.JournalFileParser
Parses a journal file and returns the next entry from the journal file.
next() - Method in class alluxio.master.journal.ufs.UfsJournalFileParser
 
next(RocksIterator) - Method in interface alluxio.master.metastore.rocks.RocksUtils.RocksIteratorParser
Parses and return next element.
next() - Method in class alluxio.resource.CloseableIterator
 
next() - Method in class alluxio.underfs.ObjectUnderFileSystem.UfsStatusIterator
 
next() - Method in class alluxio.worker.block.BlockMapIterator
 
next() - Method in class alluxio.worker.block.RegisterStreamer
 
NEXT_CONTAINER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
nextCheckpoint() - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat.CompoundCheckpointReader
Returns an entry for the next checkpoint.
nextComplete() - Method in class alluxio.concurrent.jsr.CountedCompleter
If this task does not have a completer, invokes ForkJoinTask.quietlyComplete() and returns null.
nextDepth(BaseFileStructure) - Method in class alluxio.BaseThreadState
 
nextEntry() - Method in class alluxio.master.journal.checkpoint.JournalCheckpointFormat.JournalCheckpointReader
 
nextFileId(BaseFileStructure, int) - Method in class alluxio.BaseThreadState
 
nextJobs() - Method in class alluxio.job.workflow.composite.CompositeExecution
 
nextJobs() - Method in class alluxio.job.workflow.WorkflowExecution
Given the previous set of jobs were completed successfully, returns a list of jobs to execute next.
nextLong() - Method in class alluxio.master.journal.checkpoint.LongsCheckpointFormat.LongsCheckpointReader
 
nextWidth(BaseFileStructure) - Method in class alluxio.BaseThreadState
 
NioDataBuffer - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a ByteBuffer.
NioDataBuffer(ByteBuffer, long) - Constructor for class alluxio.network.protocol.databuffer.NioDataBuffer
 
NioDirectBufferPool - Class in alluxio.network.protocol.databuffer
Direct buffer pool.
NioDirectBufferPool() - Constructor for class alluxio.network.protocol.databuffer.NioDirectBufferPool
 
NO_ACCESS_VALUE - Static variable in enum alluxio.grpc.UfsPMode
NO_ACCESS = 1;
NO_ACCESS_VALUE - Static variable in enum alluxio.proto.journal.File.UfsMode
NO_ACCESS = 0;
NO_AUTO_PERSIST - Static variable in class alluxio.Constants
 
NO_CACHE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
NO_CACHE_VALUE - Static variable in enum alluxio.grpc.ReadPType
NO_CACHE = 1;
NO_FLAGS - Static variable in class alluxio.fuse.AlluxioJniRenameUtils
 
NO_MEDIUM - Static variable in class alluxio.master.file.meta.MutableInode
 
NO_PARENT - Static variable in class alluxio.master.file.meta.InodeTree
Value to be used for an inode with no parent.
NO_SCHEME - Static variable in class alluxio.Constants
 
NO_SUCH_BUCKET - Static variable in class alluxio.s3.S3ErrorCode.Name
 
NO_SUCH_BUCKET - Static variable in class alluxio.s3.S3ErrorCode
 
NO_SUCH_KEY - Static variable in class alluxio.s3.S3ErrorCode.Name
 
NO_SUCH_KEY - Static variable in class alluxio.s3.S3ErrorCode
 
NO_SUCH_UPLOAD - Static variable in class alluxio.s3.S3ErrorCode.Name
 
NO_SUCH_UPLOAD - Static variable in class alluxio.s3.S3ErrorCode
 
NO_TTL - Static variable in class alluxio.Constants
 
NoAuthority - Class in alluxio.uri
A Singleton of NoAuthority, it represents a URI without authority.
NoCompressionMarshaller - Class in alluxio.util.compression
Simple marshaller that applies no compression.
NoCompressionMarshaller() - Constructor for class alluxio.util.compression.NoCompressionMarshaller
 
NoDataReadStreamObserver() - Constructor for class alluxio.client.block.stream.DefaultBlockWorkerClient.NoDataReadStreamObserver
 
NODE_STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetNodeStatePResponse
 
NodeInfo - Class in alluxio.util.webui
Class to make referencing worker nodes more intuitive.
NodeInfo(WorkerInfo) - Constructor for class alluxio.util.webui.NodeInfo
Instantiates a new Node info.
NodesCommand - Class in alluxio.cli.fsadmin.command
Command to get or administrate worker nodes status.
NodesCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.NodesCommand
 
NodeState - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.journal.NodeState
NoExceptionCacheManager - Class in alluxio.client.file.cache
A wrapper class of CacheManager without throwing unchecked exceptions.
NoExceptionCacheManager(CacheManager) - Constructor for class alluxio.client.file.cache.NoExceptionCacheManager
 
noFlags(int) - Static method in class alluxio.fuse.AlluxioJniRenameUtils
Checks if the rename without flag.
NON_RECURSIVE - Static variable in class alluxio.underfs.options.DeleteOptions
 
NondeterministicLRUCacheEvictor - Class in alluxio.client.file.cache.evictor
LRU with non-deterministic cache eviction policy.
NondeterministicLRUCacheEvictor(CacheEvictorOptions) - Constructor for class alluxio.client.file.cache.evictor.NondeterministicLRUCacheEvictor
Consturctor.
None_VALUE - Static variable in enum alluxio.grpc.BackupState
None = 1;
NONE_VALUE - Static variable in enum alluxio.grpc.Bits
NONE = 1;
NONE_VALUE - Static variable in enum alluxio.grpc.LoadDescendantPType
NONE = 0;
NONE_VALUE - Static variable in enum alluxio.grpc.Scope
NONE = 0;
NONE_VALUE - Static variable in enum alluxio.grpc.WritePType
NONE = 6;
NonUniqueFieldIndex<T,V> - Class in alluxio.collections
A class representing a non-unique index.
NonUniqueFieldIndex(IndexDefinition<T, V>) - Constructor for class alluxio.collections.NonUniqueFieldIndex
Constructs a new NonUniqueFieldIndex instance.
NOOP - Static variable in class alluxio.master.file.RpcContext
 
NoopBlockDeletionContext - Class in alluxio.master.file
Implementation of DefaultBlockDeletionContext which does nothing.
NoopBlockDeletionContext() - Constructor for class alluxio.master.file.NoopBlockDeletionContext
 
noopCloseable(Iterator<? extends T>) - Static method in class alluxio.resource.CloseableIterator
Wraps around an iterator with no resource to close.
NoopCloseable - Class in alluxio.resource
A noop closeable that does nothing upon close.
NoopHdfsAclProvider - Class in alluxio.underfs.hdfs
The noop HDFS ACL provider.
NoopHdfsAclProvider() - Constructor for class alluxio.underfs.hdfs.NoopHdfsAclProvider
 
NoopJournal - Class in alluxio.master.journal.noop
Implementation of Journal that does nothing.
NoopJournal() - Constructor for class alluxio.master.journal.noop.NoopJournal
Creates a new instance of NoopJournal.
NoopJournalContext - Class in alluxio.master.journal
Noop version of JournalContext.
NoopJournaled - Interface in alluxio.master.journal
Interface providing default implementations which do nothing.
NoopJournalSystem - Class in alluxio.master.journal.noop
Journal system which doesn't do anything.
NoopJournalSystem() - Constructor for class alluxio.master.journal.noop.NoopJournalSystem
Constructs a new NoopJournalSystem.
NoopMaster - Class in alluxio.master
Master implementation that does nothing.
NoopMaster() - Constructor for class alluxio.master.NoopMaster
Creates a new NoopMaster.
NoopMaster(String) - Constructor for class alluxio.master.NoopMaster
Creates a new NoopMaster with the given name.
NoopMaster(String, UfsManager) - Constructor for class alluxio.master.NoopMaster
Creates a new NoopMaster with the given name and ufsManager.
NoopPlanConfig - Class in alluxio.job.plan
Config for a plan that does nothing.
NoopPlanConfig() - Constructor for class alluxio.job.plan.NoopPlanConfig
Constructs a new instance.
NoopPlanDefinition - Class in alluxio.job.plan
This definition of a plan that does nothing.
NoopPlanDefinition() - Constructor for class alluxio.job.plan.NoopPlanDefinition
Constructs a new instance.
NoopRecorder - Class in alluxio.recorder
A Recorder which does nothing.
noopRecorder() - Static method in class alluxio.recorder.Recorder
Gets a NoopRecorder that does not actually record anything.
NoopService - Class in alluxio.master.service
Simple service that does nothing.
NoopService() - Constructor for class alluxio.master.service.NoopService
 
NoopUfsAbsentPathCache - Class in alluxio.master.file.meta
This is a noop version of UfsAbsentPathCache.
NoopUfsAbsentPathCache() - Constructor for class alluxio.master.file.meta.NoopUfsAbsentPathCache
Creates a new instance of NoopUfsAbsentPathCache.
NoopUfsDeleter - Class in alluxio.master.file
A noop version of the UfsDeleter.
NoopUfsDeleter() - Constructor for class alluxio.master.file.NoopUfsDeleter
 
NoopUfsManager - Class in alluxio.master
Implementation of UfsManager that does nothing.
NoopUfsManager() - Constructor for class alluxio.master.NoopUfsManager
 
NoopUserState - Class in alluxio.security.user
A UserState implementation which does nothing.
NoopUserState.Factory - Class in alluxio.security.user
Factory class to create the user state.
noreplace(int) - Static method in class alluxio.fuse.AlluxioJniRenameUtils
Checks if the rename flag contains RENAME_NOREPLACE flag.
normalize(List<Interval>) - Static method in class alluxio.master.predicate.interval.IntervalUtils
 
normalizePath(String) - Static method in class alluxio.AlluxioURI
Normalize the path component of the AlluxioURI, by replacing all "//" and "\\" with "/", and trimming trailing slash from non-root path (ignoring windows drive).
normalizePath(String, String) - Static method in class alluxio.util.io.PathUtils
Adds a trailing separator if it does not exist in path.
normalizeRatisMetric(String, List<String>, List<String>) - Method in class alluxio.metrics.sink.RatisNameRewriteSampleBuilder
 
NOSASL_VALUE - Static variable in enum alluxio.grpc.ChannelAuthenticationScheme
NOSASL = 0;
not() - Method in enum alluxio.security.authorization.Mode.Bits
 
NOT_FOUND_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
NotFound means some requested entity (e.g., file or directory) was not found.
NOT_IMPLEMENTED - Static variable in class alluxio.s3.S3ErrorCode.Name
 
NOT_IMPLEMENTED - Static variable in class alluxio.s3.S3ErrorCode
 
Not_Initially_Synced_VALUE - Static variable in enum alluxio.grpc.SyncPointStatus
Not_Initially_Synced = 0;
NotFoundException - Exception in alluxio.exception.status
Exception indicating that some requested entity (e.g., file or directory) was not found.
NotFoundException(String) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundException(Throwable) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that some requested entity (e.g., file or directory) was not found.
NotFoundRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.NotFoundRuntimeException
Constructor.
NotFoundRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.NotFoundRuntimeException
Constructor.
NotFoundRuntimeException(String) - Constructor for exception alluxio.exception.runtime.NotFoundRuntimeException
Constructor.
Nothing_VALUE - Static variable in enum alluxio.grpc.CommandType
Nothing = 1;
notifyChannelClosed() - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
Notifies the state machine that the channel has been closed.
notifyChannelException(Throwable) - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
Notify the state machine that a channel exception occur.
notifyConfigurationChanged(long, long, RaftProtos.RaftConfigurationProto) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
notifyInstallSnapshotFromLeader(RaftProtos.RoleInfoProto, TermIndex) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
notifyInvalidation(AlluxioURI) - Method in class alluxio.master.file.meta.UfsSyncPathCache
Notify that a path has been invalidated.
notifyLeaderChanged(RaftGroupMemberId, RaftPeerId) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
notifyLeadershipStateChanged(boolean) - Method in class alluxio.master.journal.raft.RaftJournalSystem
Notifies the journal that the leadership state has changed.
notifyNotLeader(Collection<TransactionContext>) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
notifyPrimaryMasterStarted() - Method in class alluxio.master.DefaultSafeModeManager
 
notifyPrimaryMasterStarted() - Method in interface alluxio.master.SafeModeManager
Notifies SafeModeManager that the primary master is started.
notifyRpcServerStarted() - Method in class alluxio.master.DefaultSafeModeManager
 
notifyRpcServerStarted() - Method in interface alluxio.master.SafeModeManager
Notifies SafeModeManager that the RPC server is started.
notifyStateChanged(NodeState) - Method in class alluxio.master.journal.raft.RaftPrimarySelector
Notifies leadership state changed.
notifySuccess() - Method in class alluxio.multi.process.MultiProcessCluster
Informs the cluster that the test succeeded.
notifySyncedPath(AlluxioURI, DescendantType, long, Long, boolean) - Method in class alluxio.master.file.meta.UfsSyncPathCache
Notify sync happened.
notifyTaskCompletion(long, long, Serializable) - Method in class alluxio.worker.job.task.TaskExecutorManager
Notifies the completion of the task.
notifyTaskFailure(long, long, Throwable) - Method in class alluxio.worker.job.task.TaskExecutorManager
Notifies the failure of the task.
notifyTaskRunning(long, long) - Method in class alluxio.worker.job.task.TaskExecutorManager
Noitfy the start of the task.
notifyWorkerId(NotifyWorkerIdPRequest, StreamObserver<NotifyWorkerIdPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
Notify all masters about the worker ID.
notifyWorkerId(NotifyWorkerIdPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
Notify all masters about the worker ID.
notifyWorkerId(NotifyWorkerIdPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
Notify all masters about the worker ID.
notifyWorkerId(NotifyWorkerIdPRequest, StreamObserver<NotifyWorkerIdPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Notify all masters about the worker ID.
notifyWorkerId(long, WorkerNetAddress) - Method in interface alluxio.master.block.BlockMaster
Notify the worker id to a master.
notifyWorkerId(NotifyWorkerIdPRequest, StreamObserver<NotifyWorkerIdPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
notifyWorkerId(long, WorkerNetAddress) - Method in class alluxio.master.block.DefaultBlockMaster
 
notifyWorkerId(long, WorkerNetAddress) - Method in class alluxio.worker.block.BlockMasterClient
Notify all masters about the worker ID.
NotifyWorkerIdPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.NotifyWorkerIdPOptions
NotifyWorkerIdPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.NotifyWorkerIdPOptions
NotifyWorkerIdPOptionsOrBuilder - Interface in alluxio.grpc
 
NotifyWorkerIdPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.NotifyWorkerIdPRequest
NotifyWorkerIdPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.NotifyWorkerIdPRequest
NotifyWorkerIdPRequestOrBuilder - Interface in alluxio.grpc
 
NotifyWorkerIdPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.NotifyWorkerIdPResponse
NotifyWorkerIdPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.NotifyWorkerIdPResponse
NotifyWorkerIdPResponseOrBuilder - Interface in alluxio.grpc
 
NUM_DISTINCTS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DateColumnStatsData
 
NUM_DISTINCTS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DecimalColumnStatsData
 
NUM_DISTINCTS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DoubleColumnStatsData
 
NUM_DISTINCTS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LongColumnStatsData
 
NUM_DISTINCTS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.StringColumnStatsData
 
NUM_FALSES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BooleanColumnStatsData
 
NUM_NULLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BinaryColumnStatsData
 
NUM_NULLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BooleanColumnStatsData
 
NUM_NULLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DateColumnStatsData
 
NUM_NULLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DecimalColumnStatsData
 
NUM_NULLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DoubleColumnStatsData
 
NUM_NULLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LongColumnStatsData
 
NUM_NULLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.StringColumnStatsData
 
NUM_TRUES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BooleanColumnStatsData
 
NUMACTIVETASKS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
numInodes() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
numInodes() - Method in interface alluxio.master.file.meta.InodeLockList
 
numInodes() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
numPages() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
numPages() - Method in interface alluxio.client.file.cache.PageMetaStore
 

O

OBJECT_MAPPER - Static variable in class alluxio.metrics.sink.MetricsServlet
 
OBJECT_PARAM - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
OBJECT_PATH_PATTERN - Static variable in class alluxio.proxy.s3.S3Handler
 
OBJECT_PATH_PATTERN - Static variable in class alluxio.worker.s3.S3NettyHandler
 
objectCommonPrefixesIsDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for checking directory in object storage.
objectCommonPrefixesListStatusNonRecursiveTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing status non recursively in object storage.
objectCommonPrefixesListStatusRecursiveTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing status recursively in object storage.
ObjectLowLevelOutputStream - Class in alluxio.underfs
[Experimental] A stream for writing a file into object storage using streaming upload.
ObjectLowLevelOutputStream(String, String, ListeningExecutorService, long, AlluxioConfiguration) - Constructor for class alluxio.underfs.ObjectLowLevelOutputStream
Constructs a new stream for writing a file.
ObjectMultipartUploadOutputStream - Class in alluxio.underfs
Upload File to object storage in multiple parts.
ObjectMultipartUploadOutputStream(String, String, ListeningExecutorService, long, AlluxioConfiguration) - Constructor for class alluxio.underfs.ObjectMultipartUploadOutputStream
Constructs a new stream for writing a file.
objectNestedDirsListStatusRecursiveTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for listing status recursively in nested directory in object storage.
ObjectPermissions(String, String, short) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
Creates a new ObjectPermissions.
ObjectPositionReader - Class in alluxio.underfs
A stream for reading data using position reader.
ObjectPositionReader(String, String, long) - Constructor for class alluxio.underfs.ObjectPositionReader
 
ObjectSizeCalculator - Class in alluxio.util
Contains utility methods for calculating the memory usage of objects.
ObjectSizeCalculator(ObjectSizeCalculator.MemoryLayoutSpecification) - Constructor for class alluxio.util.ObjectSizeCalculator
Creates an object size calculator that can calculate object sizes for a given memoryLayoutSpecification.
ObjectSizeCalculator(ObjectSizeCalculator.MemoryLayoutSpecification, Set<Class<?>>) - Constructor for class alluxio.util.ObjectSizeCalculator
Creates an object size calculator that can calculate object sizes for a given memoryLayoutSpecification.
ObjectSizeCalculator(ObjectSizeCalculator) - Constructor for class alluxio.util.ObjectSizeCalculator
Creates an object size calculator based on a previous one.
ObjectSizeCalculator.MemoryLayoutSpecification - Interface in alluxio.util
Describes constant memory overheads for various constructs in a JVM implementation.
ObjectStatus(String, String, long, Long) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
ObjectStatus(String) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
ObjectUnderFileSystem - Class in alluxio.underfs
An object based abstract UnderFileSystem.
ObjectUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.ObjectUnderFileSystem
Constructs an ObjectUnderFileSystem.
ObjectUnderFileSystem.DeleteBuffer - Class in alluxio.underfs
Object keys added to a ObjectUnderFileSystem.DeleteBuffer will be deleted in batches.
ObjectUnderFileSystem.ObjectListingChunk - Interface in alluxio.underfs
A chunk of listing results.
ObjectUnderFileSystem.ObjectPermissions - Class in alluxio.underfs
Permissions in object UFS.
ObjectUnderFileSystem.ObjectStatus - Class in alluxio.underfs
Information about a single object in object UFS.
ObjectUnderFileSystem.ObjectStoreOperation<T> - Interface in alluxio.underfs
Represents an object store operation.
ObjectUnderFileSystem.OperationBuffer<T> - Class in alluxio.underfs
Operations added to this buffer are performed concurrently.
ObjectUnderFileSystem.RenameBuffer - Class in alluxio.underfs
File paths added to a ObjectUnderFileSystem.RenameBuffer will be renamed concurrently.
ObjectUnderFileSystem.UfsStatusIterator - Class in alluxio.underfs
The UFS status iterator that iterates the ufs statuses and fetches the chunk by lazy.
OBS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
OBS_BUCKET_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_BUCKET_TYPE - Static variable in class alluxio.conf.PropertyKey
 
OBS_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
OBS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
ObsClientExt - Class in alluxio.underfs.obs
An extension of ObsClient to support config.
ObsClientExt(String, String, String, Map<String, Object>) - Constructor for class alluxio.underfs.obs.ObsClientExt
Construct obs client.
OBSInputStream - Class in alluxio.underfs.obs
A stream for reading a file from OBS.
OBSLowLevelOutputStream - Class in alluxio.underfs.obs
ObjectLowLevelOutputStream implement for OBS.
OBSLowLevelOutputStream(String, String, IObsClient, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.obs.OBSLowLevelOutputStream
Constructs a new stream for writing a file.
OBSMultipartUploadOutputStream - Class in alluxio.underfs.obs
Object storage multipart upload for obs.
OBSMultipartUploadOutputStream(String, String, ObsClient, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.obs.OBSMultipartUploadOutputStream
Constructs a new stream for writing a file.
OBSOutputStream - Class in alluxio.underfs.obs
A stream for writing a file into OBS.
OBSOutputStream(String, String, ObsClient, List<String>) - Constructor for class alluxio.underfs.obs.OBSOutputStream
Creates a name instance of OBSOutputStream.
OBSPositionReader - Class in alluxio.underfs.obs
Implementation of ObjectPositionReader that reads from OBS object store.
OBSPositionReader(ObsClient, String, String, long) - Constructor for class alluxio.underfs.obs.OBSPositionReader
 
OBSUnderFileSystem - Class in alluxio.underfs.obs
Huawei OBS UnderFileSystem implementation.
OBSUnderFileSystem(AlluxioURI, ObsClient, String, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.obs.OBSUnderFileSystem
Constructor for OBSUnderFileSystem.
OBSUnderFileSystemFactory - Class in alluxio.underfs.obs
Factory for creating OBSUnderFileSystem.
OBSUnderFileSystemFactory() - Constructor for class alluxio.underfs.obs.OBSUnderFileSystemFactory
Constructs a new OBSUnderFileSystemFactory.
obtrudeException(Throwable) - Method in class alluxio.concurrent.jsr.CompletableFuture
Forcibly causes subsequent invocations of method CompletableFuture.get() and related methods to throw the given exception, whether or not already completed.
obtrudeValue(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
Forcibly sets or resets the value subsequently returned by method CompletableFuture.get() and related methods, whether or not already completed.
of(long) - Static method in class alluxio.file.FileId
Gets a long-based file ID.
of(String) - Static method in class alluxio.file.FileId
Gets a String-based file ID.
of(ByteBuffer) - Static method in class alluxio.jnifuse.struct.FileStat
 
of(ByteBuffer) - Static method in class alluxio.jnifuse.struct.FuseContext
 
of(ByteBuffer) - Static method in class alluxio.jnifuse.struct.FuseFileInfo
 
of(ByteBuffer) - Static method in class alluxio.jnifuse.struct.Statvfs
 
of(List<String>) - Static method in class alluxio.worker.http.HttpRequestUri
Create a HttpRequestUri object from a list of fields.
offer(E) - Method in class alluxio.master.scheduler.Scheduler.BoundedPriorityBlockingQueue
 
offer(T) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
offer(T, long, TimeUnit) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
offerBuffer(TBuf, TMesg) - Method in interface alluxio.grpc.BufferRepository
Stores a buffer in the repository.
offerBuffer(DataBuffer, T) - Method in class alluxio.grpc.DataMessageMarshaller
 
offset() - Method in class alluxio.file.ByteArrayTargetBuffer
 
offset(int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
offset() - Method in class alluxio.file.ByteBufferTargetBuffer
 
offset(int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
offset() - Method in class alluxio.file.NettyBufTargetBuffer
 
offset(int) - Method in class alluxio.file.NettyBufTargetBuffer
 
offset() - Method in interface alluxio.file.ReadTargetBuffer
 
offset(int) - Method in interface alluxio.file.ReadTargetBuffer
Sets the new offset in the buffer.
OFFSET_FIELD_NUMBER - Static variable in class alluxio.grpc.FileBlockInfo
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteResponse
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
OFFSET_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
OFFSET_IN_FILE_FIELD_NUMBER - Static variable in class alluxio.grpc.Block
 
OFFSET_IN_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
OFFSET_RECEIVED_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
OFFSETCOUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
 
OFFSETID_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
 
OFFSETRECEIVED_FIELD_NUMBER - Static variable in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
OFFSETRECEIVED_FIELD_NUMBER - Static variable in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
ofNonUnique(Function<T, V>) - Static method in class alluxio.collections.IndexDefinition
Creates a new, non-unique index definition.
ofOrdinal(int) - Static method in enum alluxio.security.authorization.AclAction
 
ofUnique(Function<T, V>) - Static method in class alluxio.collections.IndexDefinition
Creates a new, unique index definition.
OK_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
OK is returned on success.
OLD_JOURNALS_RESOURCE - Static variable in class alluxio.master.backcompat.BackwardsCompatibilityJournalGenerator
 
onAbortBlock(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when aborting a temporary block.
onAccessBlock(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when accessing a block.
onAccessBlock(long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when accessing a block.
onBlockLost(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a block is lost.
onCacheRemove(K) - Method in class alluxio.master.metastore.caching.Cache
Callback triggered when a key is removed from the cache.
onCacheUpdate(K, V) - Method in class alluxio.master.metastore.caching.Cache
Callback triggered when an update is made to a key/value pair in the cache.
ONCE_VALUE - Static variable in enum alluxio.grpc.LoadMetadataPType
Load metadata only once.
onClose(Consumer<GrpcMessagingConnection>) - Method in class alluxio.master.transport.GrpcMessagingConnection
Adds a close listener.
onCommitBlockToLocal(long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when committing a temporary block to a BlockStoreLocation at local block store.
onCommitBlockToMaster(long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a temporary block has been committed to the alluxio master.
onCompleted() - Method in class alluxio.client.block.stream.DataMessageClientResponseObserver
 
onCompleted() - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient.NoDataReadStreamObserver
 
onCompleted() - Method in class alluxio.master.block.RegisterStreamObserver
 
onCompleted() - Method in class alluxio.master.transport.GrpcMessagingConnection
 
onCompleted() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
onCompleted() - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
 
onCompleted() - Method in class alluxio.worker.grpc.DataMessageServerRequestObserver
 
onCompleted() - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
onCompleted() - Method in class alluxio.worker.grpc.FileReadHandler
 
onCompletion(CountedCompleter<?>) - Method in class alluxio.concurrent.jsr.CountedCompleter
Performs an action when method CountedCompleter.tryComplete() is invoked and the pending count is zero, or when the unconditional method CountedCompleter.complete(T) is invoked.
ONE_MIN_EXP_BACKOFF - Static variable in class alluxio.worker.AlluxioWorkerMonitor
 
ONE_VALUE - Static variable in enum alluxio.grpc.LoadDescendantPType
ONE = 1;
onError(Throwable) - Method in class alluxio.client.block.stream.DataMessageClientResponseObserver
 
onError(Throwable) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient.NoDataReadStreamObserver
 
onError(Throwable) - Method in class alluxio.master.block.RegisterStreamObserver
 
onError(Throwable) - Method in class alluxio.master.file.ListStatusPartialResultStream
Called if an error occurs during a partial listing.
onError(Throwable) - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
 
onError(Throwable) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
onError(Throwable) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
onError(Throwable) - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
 
onError(Throwable) - Method in class alluxio.thread.AutopsyThread
Handles the uncaught error on thread crashing.
onError(Throwable) - Method in class alluxio.worker.grpc.DataMessageServerRequestObserver
 
onError(Throwable) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
onError(Throwable) - Method in class alluxio.worker.grpc.FileReadHandler
 
onException(Consumer<Throwable>) - Method in class alluxio.master.transport.GrpcMessagingConnection
Adds an exception listener.
onExceptionalCompletion(Throwable, CountedCompleter<?>) - Method in class alluxio.concurrent.jsr.CountedCompleter
Performs an action when method ForkJoinTask.completeExceptionally(Throwable) is invoked or method CountedCompleter.compute() throws an exception, and this task has not already otherwise completed normally.
ONLY_RESERVE_SPACE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
onMoveBlockByClient(long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when moving a block by a client from a BlockStoreLocation to another.
onMoveBlockByWorker(long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when moving a block by a worker from a BlockStoreLocation to another.
onNewDelete(String) - Method in interface alluxio.membership.StateListener
Act on detecting new delete on the key.
onNewPut(String, byte[]) - Method in interface alluxio.membership.StateListener
Act on detecting new put on the key.
onNext(RespT) - Method in class alluxio.client.block.stream.DataMessageClientResponseObserver
 
onNext(ReadResponse) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient.NoDataReadStreamObserver
 
onNext(RegisterWorkerPRequest) - Method in class alluxio.master.block.RegisterStreamObserver
 
onNext(TransportMessage) - Method in class alluxio.master.transport.GrpcMessagingConnection
 
onNext(SaslMessage) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
onNext(SaslMessage) - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
 
onNext(ResT) - Method in class alluxio.worker.grpc.DataMessageServerRequestObserver
 
onNext(DataMessage<T, DataBuffer>) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
Receives a message with data buffer from the stream.
onNext(T) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
onNext(ReadRequest) - Method in class alluxio.worker.grpc.FileReadHandler
 
onPlanStatusChange(PlanInfo) - Method in class alluxio.master.job.workflow.WorkflowTracker
Updates internal state of the workflows based on the updated state of a plan.
onPut(K, V, V, boolean) - Method in class alluxio.master.metastore.caching.Cache
Callback triggered whenever a new key/value pair is added by put(key, value).
onReady() - Method in class alluxio.worker.grpc.FileReadHandler
Ready to restart data reader.
onRemove(K) - Method in class alluxio.master.metastore.caching.Cache
Callback triggered whenever a key is removed by remove(key).
onRemoveBlock(long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block.
onRemoveBlockByClient(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block.
onRemoveBlockByWorker(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block by worker.
onStart() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Initializes internal state after construction but before processing any tasks.
onStateChange(Consumer<NodeState>) - Method in class alluxio.master.AbstractPrimarySelector
 
onStateChange(Consumer<NodeState>) - Method in class alluxio.master.AlwaysStandbyPrimarySelector
 
onStateChange(Consumer<NodeState>) - Method in interface alluxio.master.PrimarySelector
Registers a listener to be executed whenever the selector's state updates.
onStorageLost(String, String) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a storage dir is lost.
onStorageLost(BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a storage dir is lost.
onSuccess() - Method in class alluxio.client.file.FileSystemContextReinitializer
Notifies that the reinitialization has succeeded.
onTaskSubmitFailure(Task<?>) - Method in class alluxio.master.job.AbstractJob
 
onTaskSubmitFailure(Task<?>) - Method in class alluxio.master.job.LoadJob
 
onTaskSubmitFailure(Task<?>) - Method in interface alluxio.scheduler.job.Job
Define how to process task that gets rejected when scheduler tried to kick off.
onTermination(Throwable) - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Performs cleanup associated with termination of this worker thread.
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAclEntry
 
OP_TIME_MS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
open(URIStatus) - Method in interface alluxio.client.file.cache.LocalCacheFileInStream.FileInStreamOpener
Opens an FSDataInputStream at the indicated Path.
open(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
open(String, OpenOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
open(String, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
open(String, FuseFileInfo) - Method in class alluxio.fuse.StackFS
 
open(Path, int) - Method in class alluxio.hadoop.AbstractFileSystem
Attempts to open the specified file for reading.
open(URIStatus) - Method in interface alluxio.hadoop.HadoopFileOpener
Opens an FSDataInputStream at the indicated Path.
open(Path, int) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
open(URIStatus, int) - Method in class alluxio.hadoop.LocalCacheFileSystem
A wrapper method to default not enforce an open call.
open(URIStatus, int, boolean) - Method in class alluxio.hadoop.LocalCacheFileSystem
Attempts to open the specified file for reading.
open(String, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
open(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
open(String, OpenOptions) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
open(String, OpenOptions) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
open(String, OpenOptions) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
open(String, OpenOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
open(String) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
open(String, OpenOptions) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
open(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
open(String, OpenOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
OPEN_FILE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
OPEN_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
 
OPEN_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
 
OPEN_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
OPEN_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
OPEN_UFS_BLOCK_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
openBlock(String, long, long) - Method in class alluxio.worker.s3.S3NettyHandler
Gets a BlockReader according the ufs full path, offset and length.
openCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
opendir(String, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
OpenDirectoryException - Exception in alluxio.exception
The exception thrown when trying to call openFile on a directory.
OpenDirectoryException(String) - Constructor for exception alluxio.exception.OpenDirectoryException
Constructs a new exception with the specified detail message.
OpenDirectoryException(AlluxioURI) - Constructor for exception alluxio.exception.OpenDirectoryException
Constructs a new exception stating that the given directory cannot be opened for reading.
openExistingFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
openExistingFile(String, OpenOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
openExistingFile(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
openExistingFile(String, OpenOptions) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
openExistingFile(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
openExistingFile(String, OpenOptions) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
openExistingFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
openExistingFile(String, OpenOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
openExistingFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
openExistingFile(String, OpenOptions) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
openExistingFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
openExistingFile(String, OpenOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
openFile(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.cache.LocalCacheFileSystem
 
openFile(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.cache.LocalCacheFileSystem
 
openFile(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
openFile(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
openFile(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
openFile(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
openFile(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.openFile(AlluxioURI, OpenFilePOptions) with default options.
openFile(AlluxioURI, OpenFilePOptions) - Method in interface alluxio.client.file.FileSystem
Opens a file for reading.
openFile(URIStatus, OpenFilePOptions) - Method in interface alluxio.client.file.FileSystem
Opens a file for reading.
openFile(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
openFile(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
openFile(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
openFile(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
openFile(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
openFile(String, OpenFilePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
openFileDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
OpenFileEntry<T1 extends InputStream,T2 extends OutputStream> - Class in alluxio.fuse
Convenience class to encapsulate input/output streams of open alluxio files.
OpenFileEntry(long, String, T1, T2) - Constructor for class alluxio.fuse.OpenFileEntry
Constructs a new OpenFileEntry for an Alluxio file.
OpenFileHandle - Class in alluxio.worker.dora
Open File Handle in Dora for write request.
OpenFileHandle(String, FileInfo, CreateFilePOptions, OutputStream) - Constructor for class alluxio.worker.dora.OpenFileHandle
Construct a new open file handle.
OpenFilePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.OpenFilePOptions
OpenFilePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.OpenFilePOptions
OpenFilePOptionsOrBuilder - Interface in alluxio.grpc
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to open an input stream to an object.
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
openObjectInputStream(long, int) - Method in class alluxio.underfs.cos.COSPositionReader
 
openObjectInputStream(long, int) - Method in class alluxio.underfs.gcs.GCSPositionReader
 
openObjectInputStream(long, int) - Method in class alluxio.underfs.ObjectPositionReader
 
openObjectInputStream(long, int) - Method in class alluxio.underfs.obs.OBSPositionReader
 
openObjectInputStream(long, int) - Method in class alluxio.underfs.oss.OSSPositionReader
 
openObjectInputStream(long, int) - Method in class alluxio.underfs.s3a.S3APositionReader
 
OpenOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
OpenOptions() - Constructor for class alluxio.underfs.options.OpenOptions
Constructs a default OpenOptions.
openPositionRead(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.cache.LocalCacheFileSystem
 
openPositionRead(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.cache.LocalCacheFileSystem
 
openPositionRead(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
openPositionRead(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
openPositionRead(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
openPositionRead(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
openPositionRead(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.openPositionRead(AlluxioURI, OpenFilePOptions) with default options.
openPositionRead(AlluxioURI, OpenFilePOptions) - Method in interface alluxio.client.file.FileSystem
Opens a file for position reading.
openPositionRead(URIStatus, OpenFilePOptions) - Method in interface alluxio.client.file.FileSystem
Opens a file for reading.
openPositionRead(AlluxioURI, OpenFilePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
openPositionRead(URIStatus, OpenFilePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
openPositionRead(String, long) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
openPositionRead(String, long) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
openPositionRead(String, long) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
openPositionRead(String, long) - Method in interface alluxio.underfs.UnderFileSystem
Opens a file for position read.
openPositionRead(String, long) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
openUfsBlock(long, long, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Opens a UFS block.
operate(List<String>) - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
 
operate(List<T>) - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Operate on a list of input type T.
operate(List<Pair<String, String>>) - Method in class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
 
operation() - Method in class alluxio.stress.Parameters
Notice the function name can't be getOperation since Jackson would transfer this function in to json value, break Parameter serialization and cause serialization error.
OPERATION_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPOptions
 
OperationBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Construct a new ObjectUnderFileSystem.OperationBuffer instance.
OperationContext<T extends com.google.protobuf.GeneratedMessageV3.Builder,C extends OperationContext> - Class in alluxio.master.file.contexts
Used as a base class for wrapping context around proto messages.
OperationContext(T) - Constructor for class alluxio.master.file.contexts.OperationContext
Creates an instance with given proto message.
OperationId - Class in alluxio.wire
Used as an unique ID wrapper.
OperationId(Long, Long) - Constructor for class alluxio.wire.OperationId
Constructs and initializes a 128 bit OperationId.
OperationId(UUID) - Constructor for class alluxio.wire.OperationId
Constructs and initializes a 128 bit OperationId from an UUID.
OPERATIONID_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemMasterCommonPOptions
 
OPERATIONID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
OperationSystemGaugeSet - Class in alluxio.metrics
A set of counters for the os metric.
OperationSystemGaugeSet() - Constructor for class alluxio.metrics.OperationSystemGaugeSet
 
OperationType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.job.OperationType
OPERATIONTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdStatusBlock
 
OPERATIONTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
OPS - Static variable in class alluxio.master.backcompat.BackwardsCompatibilityJournalGenerator
 
optimalBitsPerTag(double, double) - Static method in class alluxio.client.file.cache.cuckoofilter.CuckooUtils
Compute the number of bits of each tag on given fpp.
optimalBuckets(long, double, int) - Static method in class alluxio.client.file.cache.cuckoofilter.CuckooUtils
Compute the number of buckets using the expected number of insertions, the load factor, and the number of tags per bucket.
OptimizedCheckpointInputStream - Class in alluxio.master.journal.checkpoint
InputStream to read checkpoint files efficiently.
OptimizedCheckpointInputStream(File, MessageDigest) - Constructor for class alluxio.master.journal.checkpoint.OptimizedCheckpointInputStream
 
OptimizedCheckpointOutputStream - Class in alluxio.master.journal.checkpoint
OutputStream to write checkpoint files efficiently.
OptimizedCheckpointOutputStream(File, MessageDigest) - Constructor for class alluxio.master.journal.checkpoint.OptimizedCheckpointOutputStream
 
OptimizedCheckpointOutputStream(File, MessageDigest, int) - Constructor for class alluxio.master.journal.checkpoint.OptimizedCheckpointOutputStream
Constructor used for benchmarking.
OPTIONS - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
 
OPTIONS - Static variable in class alluxio.cli.bundler.command.CollectMetricsCommand
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CancelPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckAccessPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckConsistencyPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ExistsPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetActionInfoRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetAllMasterStatusPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetAllWorkerHealthPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetBlockInfoPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusDetailedRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetCmdStatusRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetFileInfoPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobMasterIdPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobProgressPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobServiceSummaryPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobStatusDetailedPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobStatusPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMasterIdPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetPinnedFileIdsPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetPolicyStatusPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetQuorumInfoPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetRegisterLeasePResponse
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStateLockHoldersPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetUfsInfoPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerIdPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListAllPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListPolicyPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListProxyStatusPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricsHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.NotifyWorkerIdPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyInfo
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyHeartbeatPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobMasterPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobWorkerPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RemovePathConfigurationPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RemovePolicyPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RemoveQuorumServerPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ResetPrioritiesPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RunPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SetPathConfigurationPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.SubmitRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.TransferLeadershipPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.UnmountPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateMountPRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateUfsModePRequest
 
OPTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
or(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
 
ORDER_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.SortingColumn
 
orTimeout(long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
Exceptionally completes this CompletableFuture with a TimeoutException if not otherwise completed before the given timeout.
OS_LOGIN_MODULE_NAME - Static variable in class alluxio.security.login.LoginModuleConfigurationUtils
Login module according to different OS type.
OS_NAME - Static variable in class alluxio.util.OSUtils
The OS name.
OS_PRINCIPAL_CLASS_NAME - Static variable in class alluxio.security.login.LoginModuleConfigurationUtils
Class name of Principal according to different OS type.
OSS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OSS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
OSS_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
 
OSS_ENDPOINT_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OSS_ENDPOINT_KEY - Static variable in class alluxio.conf.PropertyKey
 
OSS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OSS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
OSSInputStream - Class in alluxio.underfs.oss
A stream for reading a file from OSS.
OSSLowLevelOutputStream - Class in alluxio.underfs.oss
ObjectLowLevelOutputStream implement for OSS.
OSSLowLevelOutputStream(String, String, OSS, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.oss.OSSLowLevelOutputStream
Constructs a new stream for writing a file.
OSSMultipartUploadOutputStream - Class in alluxio.underfs.oss
Object storage multipart upload for oss.
OSSMultipartUploadOutputStream(String, String, OSS, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.oss.OSSMultipartUploadOutputStream
Constructs a new stream for writing a file.
OSSOutputStream - Class in alluxio.underfs.oss
A stream for writing a file into OSS.
OSSOutputStream(String, String, OSS, List<String>) - Constructor for class alluxio.underfs.oss.OSSOutputStream
Creates a name instance of OSSOutputStream.
OSSPositionReader - Class in alluxio.underfs.oss
Implementation of ObjectPositionReader that reads from OSS object store.
OSSPositionReader(OSS, String, String, long) - Constructor for class alluxio.underfs.oss.OSSPositionReader
 
OSSUnderFileSystem - Class in alluxio.underfs.oss
Aliyun OSS UnderFileSystem implementation.
OSSUnderFileSystem(AlluxioURI, OSS, String, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.oss.OSSUnderFileSystem
Constructor for OSSUnderFileSystem.
OSSUnderFileSystemFactory - Class in alluxio.underfs.oss
Factory for creating OSSUnderFileSystem.
OSSUnderFileSystemFactory() - Constructor for class alluxio.underfs.oss.OSSUnderFileSystemFactory
Constructs a new OSSUnderFileSystemFactory.
OSUtils - Class in alluxio.util
OS related utility functions.
OTHER_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
Other_VALUE - Static variable in enum alluxio.grpc.PAclEntryType
Other = 5;
OTHER_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclEntryType
OTHER = 5;
OTHERACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
OTHERBITS_FIELD_NUMBER - Static variable in class alluxio.grpc.PMode
 
OUT_OF_RANGE_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
OutOfRange means operation was attempted past the valid range.
outList(String) - Method in class alluxio.collections.PrefixList
Checks whether a prefix of path is not in the prefix list.
OutOfRangeException - Exception in alluxio.exception.status
Exception indicating that and operation was attempted past the valid range.
OutOfRangeException(String) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeException(Throwable) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeException(String, Throwable) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that and operation was attempted past the valid range.
OutOfRangeRuntimeException(String) - Constructor for exception alluxio.exception.runtime.OutOfRangeRuntimeException
Constructor.
OUTPUT_FORMAT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.StorageFormat
 
OUTPUT_HEADER_DOMAIN - Static variable in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
OUTPUT_HEADER_LEADING_MASTER - Static variable in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
OUTPUT_HEADER_QUORUM_SIZE - Static variable in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
OUTPUT_RESULT - Static variable in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
OUTPUT_SERVER_INFO - Static variable in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
OutStreamOptions - Class in alluxio.client.file.options
Method options for writing a file.
OutStreamOptions(CreateFilePOptions, FileSystemContext, AlluxioConfiguration) - Constructor for class alluxio.client.file.options.OutStreamOptions
Creates an OutStreamOptions instance from given options.
OutStreamOptions(FileSystemContext, AlluxioConfiguration) - Constructor for class alluxio.client.file.options.OutStreamOptions
 
OVERRIDDEN_METHOD_DESCRIPTOR - Static variable in class alluxio.grpc.GrpcSerializationUtils
 
overrideMethods(ServerServiceDefinition, Map<MethodDescriptor, MethodDescriptor>) - Static method in class alluxio.grpc.GrpcSerializationUtils
Creates a service definition that uses custom marshallers.
overridePort(List<InetSocketAddress>, int) - Static method in class alluxio.util.ConfigurationUtils
Overrides the port in addresses.
OVERWRITE_ACCESS_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
OVERWRITE_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyJobPOptions
 
OVERWRITE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
OVERWRITE_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveJobPOptions
 
OVERWRITE_FIELD_NUMBER - Static variable in class alluxio.grpc.S3SyntaxOptions
 
OVERWRITE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteOptions
 
OVERWRITE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
OVERWRITE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
OVERWRITE_MODIFICATION_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
OWNER_FIELD - Static variable in class alluxio.security.authorization.AccessControlList
Keys representing owning user and group for proto ser/de.
OWNER_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.grpc.PAcl
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
OWNER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
OWNER_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
OWNER_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
Owner_VALUE - Static variable in enum alluxio.grpc.PAclEntryType
Owner = 0;
OWNER_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclEntryType
OWNER = 0;
OWNERBITS_FIELD_NUMBER - Static variable in class alluxio.grpc.PMode
 
OWNING_GROUP_FIELD - Static variable in class alluxio.security.authorization.AccessControlList
 
OWNING_GROUP_KEY - Static variable in class alluxio.security.authorization.AccessControlList
 
OWNING_GROUP_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclEntryType
OWNING_GROUP = 2;
OWNING_USER_KEY - Static variable in class alluxio.security.authorization.AccessControlList
 
OWNINGGROUP_FIELD_NUMBER - Static variable in class alluxio.grpc.PAcl
 
OWNINGGROUP_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
OwningGroup_VALUE - Static variable in enum alluxio.grpc.PAclEntryType
OwningGroup = 2;
OWNINGUSER_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
OzoneUfsConstants - Class in alluxio
Ufs constants from compilation time by maven.
OzoneUnderFileSystem - Class in alluxio.underfs.ozone
Ozone UnderFileSystem implementation.
OzoneUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.ozone.OzoneUnderFileSystem
Constructs a new Ozone UnderFileSystem.
OzoneUnderFileSystemFactory - Class in alluxio.underfs.ozone
Factory for creating OzoneUnderFileSystem.
OzoneUnderFileSystemFactory() - Constructor for class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
 

P

PAcl - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PAcl
PAcl.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PAcl
PAclAction - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.PAclAction
PAclEntry - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PAclEntry
PAclEntry.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PAclEntry
PAclEntryOrBuilder - Interface in alluxio.grpc
 
PAclEntryType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.PAclEntryType
PAclOrBuilder - Interface in alluxio.grpc
 
PagedDoraWorker - Class in alluxio.worker.dora
Page store based dora worker.
PagedDoraWorker(AtomicReference<Long>, WorkerIdentity, AlluxioConfiguration, CacheManager, MembershipManager) - Constructor for class alluxio.worker.dora.PagedDoraWorker
Constructor.
PagedDoraWorker(AtomicReference<Long>, WorkerIdentity, AlluxioConfiguration, CacheManager, MembershipManager, BlockMasterClientPool, FileSystemContext) - Constructor for class alluxio.worker.dora.PagedDoraWorker
 
PagedFileReader - Class in alluxio.worker.dora
Paged file reader.
PagedFileReader(LocalCachePositionReader, long, long) - Constructor for class alluxio.worker.dora.PagedFileReader
Constructor.
PagedFileWriter - Class in alluxio.worker.dora
A paged implementation of BlockWriter interface.
PagedService - Class in alluxio.worker.http
PagedService is used for providing page related RESTful API service.
PagedService(CacheManager) - Constructor for class alluxio.worker.http.PagedService
PagedService is used for providing page related RESTful API service.
PageId - Class in alluxio.client.file.cache
A class identifies a single cached page.
PageId(String, long) - Constructor for class alluxio.client.file.cache.PageId
 
PageInfo - Class in alluxio.client.file.cache
A class identifies the information of a single cached page.
PageInfo(PageId, long, PageStoreDir) - Constructor for class alluxio.client.file.cache.PageInfo
 
PageInfo(PageId, long, CacheScope, PageStoreDir) - Constructor for class alluxio.client.file.cache.PageInfo
 
PageInfo(PageId, long, CacheScope, PageStoreDir, long) - Constructor for class alluxio.client.file.cache.PageInfo
 
PageMetaStore - Interface in alluxio.client.file.cache
The metadata store for pages stored in cache.
PageNotFoundException - Exception in alluxio.exception
An exception that should be thrown when a page is not found in store.
PageNotFoundException(String) - Constructor for exception alluxio.exception.PageNotFoundException
Constructs a new exception with the specified detail message.
PageNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.PageNotFoundException
Constructs a new exception with the specified detail message and cause.
PAGESIZE_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
PageStore - Interface in alluxio.client.file.cache
A simple abstraction on the storage to put, get and delete pages.
PageStore.Metrics - Class in alluxio.client.file.cache
Metrics.
PageStoreDir - Interface in alluxio.client.file.cache.store
Directory of page store.
PageStoreOptions - Class in alluxio.client.file.cache.store
Options used to instantiate a PageStore.
PageStoreOptions() - Constructor for class alluxio.client.file.cache.store.PageStoreOptions
 
PageStoreType - Enum in alluxio.client.file.cache.store
This represents the different page store implementations that can be instantiated.
Pair<T1,T2> - Class in alluxio.collections
A pair representation defined by two elements (of type First and type Second).
Pair(T1, T2) - Constructor for class alluxio.collections.Pair
Constructs and initializes a Pair specified by the two input elements.
Pair() - Constructor for class alluxio.collections.Pair
Default constructor for deserialization.
parallelStream() - Method in class alluxio.collections.DelegatingSet
 
ParallelZipUtils - Class in alluxio.util.compression
Utility methods for working with parallel zip archives.
PARAMETER_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Database
 
Parameters - Class in alluxio.stress
Abstract class for parameters of stress tests.
Parameters() - Constructor for class alluxio.stress.Parameters
 
Parameters.BooleanDescription - Annotation Type in alluxio.stress
This annotation defines readable descriptions boolean parameters.
Parameters.KeylessDescription - Annotation Type in alluxio.stress
This annotation is for descriptions which do not display the key/name.
Parameters.PathDescription - Annotation Type in alluxio.stress
This annotation defines readable descriptions for paths.
PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
parametersToString(Object...) - Static method in class alluxio.util.FormatUtils
Parses a list of Objects into a String.
parent() - Method in enum alluxio.client.quota.CacheScope.Level
 
parent() - Method in class alluxio.client.quota.CacheScope
 
PARENT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PARENT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PARENT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
PARENT_ID_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
parentExists(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Treating the object store as a file system, checks if the parent directory exists.
PARENTID_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
parse(InputStream) - Method in class alluxio.grpc.DataMessageMarshaller
 
parse(String) - Static method in class alluxio.master.backcompat.Journal
 
parse(String) - Static method in class alluxio.security.authorization.ModeParser
Parses the given value as a mode.
parse(String) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
parseAndValidateArgs(String...) - Method in interface alluxio.cli.Command
Parses and validates the arguments.
parseAsList(String, String) - Static method in class alluxio.util.ConfigurationUtils
Returns the input string as a list, splitting on a specified delimiter.
parseBenchmarkResult(String) - Static method in class alluxio.job.util.SerializationUtils
Parse the actual JSON result from the benchmark output.
parseCliOptionsAsConfig(FuseCliOptions) - Static method in class alluxio.fuse.AlluxioFuse
Converts command line options into Alluxio configuration.
parseCompleteMultipartUploadRequest(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
Parse xml http body for CompleteMultipartUploadRequest.
parseCompleteMultipartUploadRequest(String) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
Parse xml http body for CompleteMultipartUploadRequest.
parseDateTime(String) - Static method in class alluxio.cli.bundler.command.CollectLogCommand
Identifies the datetime from a certain piece of log by trying various known patterns.
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ActionInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ActionInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BackupPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BackupPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BackupPStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.Block
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Block
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockIdList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockIdList
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockLocation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockLocation
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.BuildVersion
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BuildVersion
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CacheRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CacheResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CancelPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CancelPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CancelPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CheckResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.Chunk
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Chunk
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ClientMetrics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClientMetrics
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CmdProgress
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdProgress
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CmdSummary
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdSummary
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.Command
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Command
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ConfigProperties
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperties
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ConfigProperty
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperty
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CopyRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CopyResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.DeletePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.DeletePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.DeletePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ErrorInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ErrorInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ExistsPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ExistsPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ExistsPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.File
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.File
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileBlockInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileBlockInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileFailure
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileFailure
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileSystemCommand
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommand
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FreePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FreePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FreePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.FsOpPId
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FsOpPId
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.InconsistentProperties
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperties
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.InconsistentProperty
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperty
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobCommand
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobCommand
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobDescription
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobDescription
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobMasterStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobProgress
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgress
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobServiceSummary
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobServiceSummary
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobStatusBlock
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobStatusBlock
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobUnused
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobUnused
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListAllPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListAllPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListAllPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LoadFileFailure
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileFailure
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LoadFileRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LoadFileResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LoadRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LoadResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MasterInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MasterVersion
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterVersion
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.Metric
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Metric
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MetricValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricValue
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MountPointInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPointInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MountPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MountPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MountPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MoveRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.MoveResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.NetAddress
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NetAddress
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.PAcl
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAcl
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.PAclEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAclEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.PersistFile
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistFile
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.PMode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PMode
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.PolicyInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.PolicyStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ProxyStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ReadRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ReadResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterCommand
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterCommand
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RenamePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RenamePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RenamePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RetryInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RetryInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.Route
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Route
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RouteFailure
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RouteFailure
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RunPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RunPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RunPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.RunTaskCommand
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunTaskCommand
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SaslMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SaslMessage
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetAclPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetAclPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetAclPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SnapshotData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StatusSummary
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StatusSummary
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StopJobPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StopJobPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.StorageList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StorageList
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SubmitOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SubmitRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.SubmitResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Constraint
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Constraint
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Database
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Database
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Date
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Date
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Decimal
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Decimal
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Domain
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Domain
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.FieldSchema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FieldSchema
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.FileStatistics
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FileStatistics
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Layout
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Layout
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Partition
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Partition
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Range
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Range
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.RangeSet
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.RangeSet
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Schema
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Schema
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.SyncStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.TableInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TableInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Transformation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Transformation
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.table.Value
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Value
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TierList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TierList
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TransportMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransportMessage
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UfsFileStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsFileStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UfsInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UfsReadOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsReadOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UfsStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UnmountPOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UnmountPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UnmountPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WorkerIdentity
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerIdentity
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WorkerInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WriteOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WriteRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.grpc.WriteResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseDelimitedFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ActionInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddPolicyPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AddQuorumServerRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.AsyncCacheResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupPStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BackupStatusPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.Block
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.Block
 
parseFrom(ByteString) - Static method in class alluxio.grpc.Block
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.Block
 
parseFrom(byte[]) - Static method in class alluxio.grpc.Block
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.Block
 
parseFrom(InputStream) - Static method in class alluxio.grpc.Block
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Block
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.Block
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Block
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockIdList
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockLocation
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockMasterInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockStoreLocationProto
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(ByteString) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(byte[]) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(InputStream) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.BuildVersion
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CacheResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CancelTaskCommand
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckAccessPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckpointPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CheckResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.Chunk
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.Chunk
 
parseFrom(ByteString) - Static method in class alluxio.grpc.Chunk
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.Chunk
 
parseFrom(byte[]) - Static method in class alluxio.grpc.Chunk
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.Chunk
 
parseFrom(InputStream) - Static method in class alluxio.grpc.Chunk
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Chunk
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.Chunk
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Chunk
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClearMetricsResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ClientMetrics
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdProgress
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdStatusBlock
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CmdSummary
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.Command
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.Command
 
parseFrom(ByteString) - Static method in class alluxio.grpc.Command
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.Command
 
parseFrom(byte[]) - Static method in class alluxio.grpc.Command
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.Command
 
parseFrom(InputStream) - Static method in class alluxio.grpc.Command
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Command
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.Command
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Command
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CommitBlockPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CompleteFilePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigCheckReport
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperties
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ConfigProperty
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyJobPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CopyResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.CreateFilePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DeletePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ErrorInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ExistsPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.File
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.File
 
parseFrom(ByteString) - Static method in class alluxio.grpc.File
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.File
 
parseFrom(byte[]) - Static method in class alluxio.grpc.File
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.File
 
parseFrom(InputStream) - Static method in class alluxio.grpc.File
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.File
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.File
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.File
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileBlockInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileFailure
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommand
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemCommandOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FreeWorkerResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(ByteString) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(byte[]) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(InputStream) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.FsOpPId
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetActionInfoResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetCmdStatusResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigHashPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigReportPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetConfigurationPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFileInfoPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetFilePathPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobProgressPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetJobStatusPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterIdPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMetricsPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountIdPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetMountTablePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetNodeStatePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetStatusPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(ByteString) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(byte[]) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(InputStream) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperties
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(ByteString) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(byte[]) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(InputStream) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentProperty
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(ByteString) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(byte[]) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(InputStream) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.InconsistentPropertyValues
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobCommand
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobDescription
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgress
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobProgressPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobServiceSummary
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobStatusBlock
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobUnused
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JobWorkerHealth
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListAllPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListPolicyPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ListStatusPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileFailure
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadFileResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadJobPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadMetadataPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LoadResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(ByteString) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(byte[]) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(InputStream) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MasterVersion
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingRequestHeader
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingResponseHeader
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.Metric
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.Metric
 
parseFrom(ByteString) - Static method in class alluxio.grpc.Metric
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.Metric
 
parseFrom(byte[]) - Static method in class alluxio.grpc.Metric
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.Metric
 
parseFrom(InputStream) - Static method in class alluxio.grpc.Metric
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Metric
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.Metric
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Metric
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricValue
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPointInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MountPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveBlockResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveJobPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.MoveResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NeedsSyncResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(ByteString) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(byte[]) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(InputStream) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NetAddress
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.OpenFilePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.PAcl
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAcl
 
parseFrom(ByteString) - Static method in class alluxio.grpc.PAcl
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAcl
 
parseFrom(byte[]) - Static method in class alluxio.grpc.PAcl
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.PAcl
 
parseFrom(InputStream) - Static method in class alluxio.grpc.PAcl
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAcl
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.PAcl
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAcl
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(ByteString) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(byte[]) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(InputStream) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PAclEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistCommandOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(ByteString) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(byte[]) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(InputStream) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PersistFile
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.PMode
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.PMode
 
parseFrom(ByteString) - Static method in class alluxio.grpc.PMode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.PMode
 
parseFrom(byte[]) - Static method in class alluxio.grpc.PMode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.PMode
 
parseFrom(InputStream) - Static method in class alluxio.grpc.PMode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PMode
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.PMode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PMode
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ProxyStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.QuorumServerInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReadResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterCommand
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterMasterPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveBlockResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemovePolicyPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RenamePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RetryInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ReverseResolvePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.Route
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.Route
 
parseFrom(ByteString) - Static method in class alluxio.grpc.Route
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.Route
 
parseFrom(byte[]) - Static method in class alluxio.grpc.Route
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.Route
 
parseFrom(InputStream) - Static method in class alluxio.grpc.Route
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Route
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.Route
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.Route
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RouteFailure
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(ByteString) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(byte[]) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(InputStream) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.RunTaskCommand
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.S3SyntaxOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SaslMessage
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAclPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetAttributePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SnapshotMetadata
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StatusSummary
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StopJobPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.StorageList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.StorageList
 
parseFrom(ByteString) - Static method in class alluxio.grpc.StorageList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.StorageList
 
parseFrom(byte[]) - Static method in class alluxio.grpc.StorageList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.StorageList
 
parseFrom(InputStream) - Static method in class alluxio.grpc.StorageList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StorageList
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.StorageList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.StorageList
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitJobPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.SubmitResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AllOrNoneSet
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Constraint
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Database
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Database
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Database
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Database
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Database
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Database
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Database
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Database
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Database
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Database
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Date
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Date
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Date
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Date
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Date
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Date
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Date
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Date
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Date
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Date
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DateColumnStatsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Decimal
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Domain
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.EquatableValueSet
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FieldSchema
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.FileStatistics
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTablePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.Storage
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Layout
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LayoutSpec
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.LongColumnStatsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Partition
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.PartitionSpec
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Range
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Range
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Range
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Range
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Range
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Range
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Range
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Range
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Range
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Range
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.RangeSet
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.ReadTablePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Schema
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.StringColumnStatsData
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.SyncStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TableInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Transformation
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformJobInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TransformTablePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.table.Value
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Value
 
parseFrom(ByteString) - Static method in class alluxio.grpc.table.Value
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Value
 
parseFrom(byte[]) - Static method in class alluxio.grpc.table.Value
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Value
 
parseFrom(InputStream) - Static method in class alluxio.grpc.table.Value
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Value
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.table.Value
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.table.Value
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TierList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TierList
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TierList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TierList
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TierList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TierList
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TierList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TierList
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TierList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TierList
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeaderMessage
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TransportMessage
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.TriggerPolicyResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsFileStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsReadOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UfsStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UnmountPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateMountPResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(ByteString) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(byte[]) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(InputStream) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerIdentity
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WorkerNetAddress
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteRequestCommand
 
parseFrom(ByteBuffer) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(ByteString) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(byte[]) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(InputStream) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.grpc.WriteResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(ByteString) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(byte[]) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(InputStream) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(ByteString) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(byte[]) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(InputStream) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.Response
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(ByteString) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(byte[]) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(InputStream) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.RenameEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAclEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.StringPairEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.FileFilter
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(ByteString) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(byte[]) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(InputStream) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockLocation
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(ByteString) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(byte[]) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(InputStream) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block.BlockMeta
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(ByteString) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(byte[]) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(InputStream) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(ByteString) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(byte[]) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(InputStream) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(ByteString) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(byte[]) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(ByteString) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(byte[]) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclActions
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(ByteString) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(byte[]) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.AclEntry
 
parseFrom(ByteBuffer) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(ByteString) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(byte[]) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(InputStream) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(CodedInputStream) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseFrom(byte[], ProtoMessage) - Static method in class alluxio.util.proto.ProtoMessage
Parses proto message from bytes given a prototype.
parseIdentifier(ByteString) - Method in class alluxio.wire.WorkerIdentity.ParserV0
 
parseIdentifier(ByteString) - Method in class alluxio.wire.WorkerIdentity.ParserV1
 
parseInetSocketAddress(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Parses InetSocketAddress from a String.
parseInetSocketAddresses(List<String>) - Static method in class alluxio.util.ConfigurationUtils
 
parseMajorVersion(String) - Static method in class alluxio.util.CommonUtils
 
parseMountInfo(String) - Static method in class alluxio.util.ShellUtils
 
parseOptTarget(CommandLine, AlluxioConfiguration) - Static method in class alluxio.cli.LogLevel
Parse the command options to a list of targets endpoints.
parseParameters(String[]) - Method in class alluxio.stress.cli.Benchmark
 
parsePath(String) - Static method in class alluxio.proxy.s3.S3RestUtils
Format bucket path.
parsePath(String) - Static method in class alluxio.s3.NettyRestUtils
Format bucket path.
parseQueryString(String) - Static method in class alluxio.util.URIUtils
Parses the given query string, and returns a map of the query parameters.
PARSER - Static variable in class alluxio.grpc.ActionInfo
Deprecated.
parser() - Static method in class alluxio.grpc.ActionInfo
 
PARSER - Static variable in class alluxio.grpc.AddPolicyPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.AddPolicyPOptions
 
PARSER - Static variable in class alluxio.grpc.AddPolicyPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.AddPolicyPRequest
 
PARSER - Static variable in class alluxio.grpc.AddPolicyPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.AddPolicyPResponse
 
PARSER - Static variable in class alluxio.grpc.AddQuorumServerRequest
Deprecated.
parser() - Static method in class alluxio.grpc.AddQuorumServerRequest
 
PARSER - Static variable in class alluxio.grpc.AsyncCacheRequest
Deprecated.
parser() - Static method in class alluxio.grpc.AsyncCacheRequest
 
PARSER - Static variable in class alluxio.grpc.AsyncCacheResponse
Deprecated.
parser() - Static method in class alluxio.grpc.AsyncCacheResponse
 
PARSER - Static variable in class alluxio.grpc.BackupPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.BackupPOptions
 
PARSER - Static variable in class alluxio.grpc.BackupPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.BackupPRequest
 
PARSER - Static variable in class alluxio.grpc.BackupPStatus
Deprecated.
parser() - Static method in class alluxio.grpc.BackupPStatus
 
PARSER - Static variable in class alluxio.grpc.BackupStatusPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.BackupStatusPRequest
 
PARSER - Static variable in class alluxio.grpc.Block
Deprecated.
parser() - Static method in class alluxio.grpc.Block
 
PARSER - Static variable in class alluxio.grpc.BlockHeartbeatPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.BlockHeartbeatPOptions
 
PARSER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.BlockHeartbeatPRequest
 
PARSER - Static variable in class alluxio.grpc.BlockHeartbeatPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.BlockHeartbeatPResponse
 
PARSER - Static variable in class alluxio.grpc.BlockIdList
Deprecated.
parser() - Static method in class alluxio.grpc.BlockIdList
 
PARSER - Static variable in class alluxio.grpc.BlockInfo
Deprecated.
parser() - Static method in class alluxio.grpc.BlockInfo
 
PARSER - Static variable in class alluxio.grpc.BlockLocation
Deprecated.
parser() - Static method in class alluxio.grpc.BlockLocation
 
PARSER - Static variable in class alluxio.grpc.BlockMasterInfo
Deprecated.
parser() - Static method in class alluxio.grpc.BlockMasterInfo
 
PARSER - Static variable in class alluxio.grpc.BlockStatus
Deprecated.
parser() - Static method in class alluxio.grpc.BlockStatus
 
PARSER - Static variable in class alluxio.grpc.BlockStoreLocationProto
Deprecated.
parser() - Static method in class alluxio.grpc.BlockStoreLocationProto
 
PARSER - Static variable in class alluxio.grpc.BuildVersion
Deprecated.
parser() - Static method in class alluxio.grpc.BuildVersion
 
PARSER - Static variable in class alluxio.grpc.CacheRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CacheRequest
 
PARSER - Static variable in class alluxio.grpc.CacheResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CacheResponse
 
PARSER - Static variable in class alluxio.grpc.CancelPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CancelPOptions
 
PARSER - Static variable in class alluxio.grpc.CancelPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CancelPRequest
 
PARSER - Static variable in class alluxio.grpc.CancelPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CancelPResponse
 
PARSER - Static variable in class alluxio.grpc.CancelTaskCommand
Deprecated.
parser() - Static method in class alluxio.grpc.CancelTaskCommand
 
PARSER - Static variable in class alluxio.grpc.CheckAccessPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CheckAccessPOptions
 
PARSER - Static variable in class alluxio.grpc.CheckAccessPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CheckAccessPRequest
 
PARSER - Static variable in class alluxio.grpc.CheckAccessPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CheckAccessPResponse
 
PARSER - Static variable in class alluxio.grpc.CheckConsistencyPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CheckConsistencyPOptions
 
PARSER - Static variable in class alluxio.grpc.CheckConsistencyPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CheckConsistencyPRequest
 
PARSER - Static variable in class alluxio.grpc.CheckConsistencyPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CheckConsistencyPResponse
 
PARSER - Static variable in class alluxio.grpc.CheckpointPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CheckpointPOptions
 
PARSER - Static variable in class alluxio.grpc.CheckpointPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CheckpointPResponse
 
PARSER - Static variable in class alluxio.grpc.CheckRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CheckRequest
 
PARSER - Static variable in class alluxio.grpc.CheckResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CheckResponse
 
PARSER - Static variable in class alluxio.grpc.Chunk
Deprecated.
parser() - Static method in class alluxio.grpc.Chunk
 
PARSER - Static variable in class alluxio.grpc.ClearMetricsPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ClearMetricsPRequest
 
PARSER - Static variable in class alluxio.grpc.ClearMetricsPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ClearMetricsPResponse
 
PARSER - Static variable in class alluxio.grpc.ClearMetricsRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ClearMetricsRequest
 
PARSER - Static variable in class alluxio.grpc.ClearMetricsResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ClearMetricsResponse
 
PARSER - Static variable in class alluxio.grpc.ClientMetrics
Deprecated.
parser() - Static method in class alluxio.grpc.ClientMetrics
 
PARSER - Static variable in class alluxio.grpc.CmdProgress
Deprecated.
parser() - Static method in class alluxio.grpc.CmdProgress
 
PARSER - Static variable in class alluxio.grpc.CmdStatusBlock
Deprecated.
parser() - Static method in class alluxio.grpc.CmdStatusBlock
 
PARSER - Static variable in class alluxio.grpc.CmdSummary
Deprecated.
parser() - Static method in class alluxio.grpc.CmdSummary
 
PARSER - Static variable in class alluxio.grpc.Command
Deprecated.
parser() - Static method in class alluxio.grpc.Command
 
PARSER - Static variable in class alluxio.grpc.CommitBlockPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CommitBlockPOptions
 
PARSER - Static variable in class alluxio.grpc.CommitBlockPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CommitBlockPRequest
 
PARSER - Static variable in class alluxio.grpc.CommitBlockPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CommitBlockPResponse
 
PARSER - Static variable in class alluxio.grpc.CompleteFilePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CompleteFilePOptions
 
PARSER - Static variable in class alluxio.grpc.CompleteFilePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CompleteFilePRequest
 
PARSER - Static variable in class alluxio.grpc.CompleteFilePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CompleteFilePResponse
 
PARSER - Static variable in class alluxio.grpc.ConfigCheckReport
Deprecated.
parser() - Static method in class alluxio.grpc.ConfigCheckReport
 
PARSER - Static variable in class alluxio.grpc.ConfigProperties
Deprecated.
parser() - Static method in class alluxio.grpc.ConfigProperties
 
PARSER - Static variable in class alluxio.grpc.ConfigProperty
Deprecated.
parser() - Static method in class alluxio.grpc.ConfigProperty
 
PARSER - Static variable in class alluxio.grpc.CopyJobPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CopyJobPOptions
 
PARSER - Static variable in class alluxio.grpc.CopyRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CopyRequest
 
PARSER - Static variable in class alluxio.grpc.CopyResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CopyResponse
 
PARSER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CreateDirectoryPOptions
 
PARSER - Static variable in class alluxio.grpc.CreateDirectoryPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CreateDirectoryPRequest
 
PARSER - Static variable in class alluxio.grpc.CreateDirectoryPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CreateDirectoryPResponse
 
PARSER - Static variable in class alluxio.grpc.CreateFilePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.CreateFilePOptions
 
PARSER - Static variable in class alluxio.grpc.CreateFilePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.CreateFilePRequest
 
PARSER - Static variable in class alluxio.grpc.CreateFilePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.CreateFilePResponse
 
PARSER - Static variable in class alluxio.grpc.DecommissionWorkerPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.DecommissionWorkerPOptions
 
PARSER - Static variable in class alluxio.grpc.DecommissionWorkerPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.DecommissionWorkerPResponse
 
PARSER - Static variable in class alluxio.grpc.DeletePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.DeletePOptions
 
PARSER - Static variable in class alluxio.grpc.DeletePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.DeletePRequest
 
PARSER - Static variable in class alluxio.grpc.DeletePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.DeletePResponse
 
PARSER - Static variable in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.ErrorInfo
Deprecated.
parser() - Static method in class alluxio.grpc.ErrorInfo
 
PARSER - Static variable in class alluxio.grpc.ExistsPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ExistsPOptions
 
PARSER - Static variable in class alluxio.grpc.ExistsPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ExistsPRequest
 
PARSER - Static variable in class alluxio.grpc.ExistsPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ExistsPResponse
 
PARSER - Static variable in class alluxio.grpc.File
Deprecated.
parser() - Static method in class alluxio.grpc.File
 
PARSER - Static variable in class alluxio.grpc.FileBlockInfo
Deprecated.
parser() - Static method in class alluxio.grpc.FileBlockInfo
 
PARSER - Static variable in class alluxio.grpc.FileFailure
Deprecated.
parser() - Static method in class alluxio.grpc.FileFailure
 
PARSER - Static variable in class alluxio.grpc.FileInfo
Deprecated.
parser() - Static method in class alluxio.grpc.FileInfo
 
PARSER - Static variable in class alluxio.grpc.FileSystemCommand
Deprecated.
parser() - Static method in class alluxio.grpc.FileSystemCommand
 
PARSER - Static variable in class alluxio.grpc.FileSystemCommandOptions
Deprecated.
parser() - Static method in class alluxio.grpc.FileSystemCommandOptions
 
PARSER - Static variable in class alluxio.grpc.FileSystemHeartbeatPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
PARSER - Static variable in class alluxio.grpc.FileSystemHeartbeatPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
PARSER - Static variable in class alluxio.grpc.FileSystemHeartbeatPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
PARSER - Static variable in class alluxio.grpc.FileSystemMasterCommonPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
PARSER - Static variable in class alluxio.grpc.FreePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.FreePOptions
 
PARSER - Static variable in class alluxio.grpc.FreePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.FreePRequest
 
PARSER - Static variable in class alluxio.grpc.FreePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.FreePResponse
 
PARSER - Static variable in class alluxio.grpc.FreeWorkerRequest
Deprecated.
parser() - Static method in class alluxio.grpc.FreeWorkerRequest
 
PARSER - Static variable in class alluxio.grpc.FreeWorkerResponse
Deprecated.
parser() - Static method in class alluxio.grpc.FreeWorkerResponse
 
PARSER - Static variable in class alluxio.grpc.FsOpPId
Deprecated.
parser() - Static method in class alluxio.grpc.FsOpPId
 
PARSER - Static variable in class alluxio.grpc.GetActionInfoOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetActionInfoOptions
 
PARSER - Static variable in class alluxio.grpc.GetActionInfoRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetActionInfoRequest
 
PARSER - Static variable in class alluxio.grpc.GetActionInfoResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetActionInfoResponse
 
PARSER - Static variable in class alluxio.grpc.GetAllMasterStatusPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetAllMasterStatusPOptions
 
PARSER - Static variable in class alluxio.grpc.GetAllMasterStatusPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetAllMasterStatusPRequest
 
PARSER - Static variable in class alluxio.grpc.GetAllMasterStatusPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetAllMasterStatusPResponse
 
PARSER - Static variable in class alluxio.grpc.GetAllWorkerHealthPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
PARSER - Static variable in class alluxio.grpc.GetAllWorkerHealthPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
PARSER - Static variable in class alluxio.grpc.GetAllWorkerHealthPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
PARSER - Static variable in class alluxio.grpc.GetBlockInfoPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetBlockInfoPOptions
 
PARSER - Static variable in class alluxio.grpc.GetBlockInfoPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetBlockInfoPRequest
 
PARSER - Static variable in class alluxio.grpc.GetBlockInfoPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetBlockInfoPResponse
 
PARSER - Static variable in class alluxio.grpc.GetBlockMasterInfoPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
PARSER - Static variable in class alluxio.grpc.GetBlockMasterInfoPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
PARSER - Static variable in class alluxio.grpc.GetCapacityBytesPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetCapacityBytesPOptions
 
PARSER - Static variable in class alluxio.grpc.GetCapacityBytesPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetCapacityBytesPResponse
 
PARSER - Static variable in class alluxio.grpc.GetCmdStatusDetailedOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
PARSER - Static variable in class alluxio.grpc.GetCmdStatusDetailedRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
PARSER - Static variable in class alluxio.grpc.GetCmdStatusDetailedResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
PARSER - Static variable in class alluxio.grpc.GetCmdStatusOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetCmdStatusOptions
 
PARSER - Static variable in class alluxio.grpc.GetCmdStatusRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetCmdStatusRequest
 
PARSER - Static variable in class alluxio.grpc.GetCmdStatusResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetCmdStatusResponse
 
PARSER - Static variable in class alluxio.grpc.GetConfigHashPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetConfigHashPOptions
 
PARSER - Static variable in class alluxio.grpc.GetConfigHashPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetConfigHashPResponse
 
PARSER - Static variable in class alluxio.grpc.GetConfigReportPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetConfigReportPOptions
 
PARSER - Static variable in class alluxio.grpc.GetConfigReportPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetConfigReportPResponse
 
PARSER - Static variable in class alluxio.grpc.GetConfigurationPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetConfigurationPOptions
 
PARSER - Static variable in class alluxio.grpc.GetConfigurationPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetConfigurationPResponse
 
PARSER - Static variable in class alluxio.grpc.GetFileInfoPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetFileInfoPOptions
 
PARSER - Static variable in class alluxio.grpc.GetFileInfoPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetFileInfoPRequest
 
PARSER - Static variable in class alluxio.grpc.GetFileInfoPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetFileInfoPResponse
 
PARSER - Static variable in class alluxio.grpc.GetFilePathPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetFilePathPRequest
 
PARSER - Static variable in class alluxio.grpc.GetFilePathPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetFilePathPResponse
 
PARSER - Static variable in class alluxio.grpc.GetJobMasterIdPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobMasterIdPOptions
 
PARSER - Static variable in class alluxio.grpc.GetJobMasterIdPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobMasterIdPRequest
 
PARSER - Static variable in class alluxio.grpc.GetJobMasterIdPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobMasterIdPResponse
 
PARSER - Static variable in class alluxio.grpc.GetJobProgressPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobProgressPRequest
 
PARSER - Static variable in class alluxio.grpc.GetJobProgressPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobProgressPResponse
 
PARSER - Static variable in class alluxio.grpc.GetJobServiceSummaryPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
PARSER - Static variable in class alluxio.grpc.GetJobServiceSummaryPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
PARSER - Static variable in class alluxio.grpc.GetJobServiceSummaryPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
PARSER - Static variable in class alluxio.grpc.GetJobStatusDetailedPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
PARSER - Static variable in class alluxio.grpc.GetJobStatusDetailedPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
PARSER - Static variable in class alluxio.grpc.GetJobStatusDetailedPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
PARSER - Static variable in class alluxio.grpc.GetJobStatusPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobStatusPOptions
 
PARSER - Static variable in class alluxio.grpc.GetJobStatusPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobStatusPRequest
 
PARSER - Static variable in class alluxio.grpc.GetJobStatusPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetJobStatusPResponse
 
PARSER - Static variable in class alluxio.grpc.GetMasterIdPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetMasterIdPOptions
 
PARSER - Static variable in class alluxio.grpc.GetMasterIdPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetMasterIdPRequest
 
PARSER - Static variable in class alluxio.grpc.GetMasterIdPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetMasterIdPResponse
 
PARSER - Static variable in class alluxio.grpc.GetMasterInfoPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetMasterInfoPOptions
 
PARSER - Static variable in class alluxio.grpc.GetMasterInfoPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetMasterInfoPResponse
 
PARSER - Static variable in class alluxio.grpc.GetMetricsPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetMetricsPOptions
 
PARSER - Static variable in class alluxio.grpc.GetMetricsPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetMetricsPResponse
 
PARSER - Static variable in class alluxio.grpc.GetMountIdPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetMountIdPRequest
 
PARSER - Static variable in class alluxio.grpc.GetMountIdPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetMountIdPResponse
 
PARSER - Static variable in class alluxio.grpc.GetMountTablePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetMountTablePRequest
 
PARSER - Static variable in class alluxio.grpc.GetMountTablePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetMountTablePResponse
 
PARSER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
PARSER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
PARSER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
PARSER - Static variable in class alluxio.grpc.GetNodeStatePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetNodeStatePRequest
 
PARSER - Static variable in class alluxio.grpc.GetNodeStatePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetNodeStatePResponse
 
PARSER - Static variable in class alluxio.grpc.GetPinnedFileIdsPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
PARSER - Static variable in class alluxio.grpc.GetPinnedFileIdsPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
PARSER - Static variable in class alluxio.grpc.GetPinnedFileIdsPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
PARSER - Static variable in class alluxio.grpc.GetPolicyStatusPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetPolicyStatusPOptions
 
PARSER - Static variable in class alluxio.grpc.GetPolicyStatusPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetPolicyStatusPRequest
 
PARSER - Static variable in class alluxio.grpc.GetPolicyStatusPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetPolicyStatusPResponse
 
PARSER - Static variable in class alluxio.grpc.GetQuorumInfoPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetQuorumInfoPOptions
 
PARSER - Static variable in class alluxio.grpc.GetQuorumInfoPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetQuorumInfoPRequest
 
PARSER - Static variable in class alluxio.grpc.GetQuorumInfoPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetQuorumInfoPResponse
 
PARSER - Static variable in class alluxio.grpc.GetRegisterLeasePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetRegisterLeasePOptions
 
PARSER - Static variable in class alluxio.grpc.GetRegisterLeasePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetRegisterLeasePRequest
 
PARSER - Static variable in class alluxio.grpc.GetRegisterLeasePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetRegisterLeasePResponse
 
PARSER - Static variable in class alluxio.grpc.GetServiceVersionPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetServiceVersionPRequest
 
PARSER - Static variable in class alluxio.grpc.GetServiceVersionPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetServiceVersionPResponse
 
PARSER - Static variable in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.GetSnapshotRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.GetStateLockHoldersPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetStateLockHoldersPOptions
 
PARSER - Static variable in class alluxio.grpc.GetStateLockHoldersPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetStateLockHoldersPRequest
 
PARSER - Static variable in class alluxio.grpc.GetStateLockHoldersPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetStateLockHoldersPResponse
 
PARSER - Static variable in class alluxio.grpc.GetStatusPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetStatusPOptions
 
PARSER - Static variable in class alluxio.grpc.GetStatusPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetStatusPRequest
 
PARSER - Static variable in class alluxio.grpc.GetStatusPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetStatusPResponse
 
PARSER - Static variable in class alluxio.grpc.GetTransferLeaderMessageOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
PARSER - Static variable in class alluxio.grpc.GetTransferLeaderMessagePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
PARSER - Static variable in class alluxio.grpc.GetTransferLeaderMessagePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
PARSER - Static variable in class alluxio.grpc.GetUfsInfoPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetUfsInfoPOptions
 
PARSER - Static variable in class alluxio.grpc.GetUfsInfoPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetUfsInfoPRequest
 
PARSER - Static variable in class alluxio.grpc.GetUfsInfoPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetUfsInfoPResponse
 
PARSER - Static variable in class alluxio.grpc.GetUsedBytesPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetUsedBytesPOptions
 
PARSER - Static variable in class alluxio.grpc.GetUsedBytesPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetUsedBytesPResponse
 
PARSER - Static variable in class alluxio.grpc.GetWorkerIdPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerIdPOptions
 
PARSER - Static variable in class alluxio.grpc.GetWorkerIdPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerIdPRequest
 
PARSER - Static variable in class alluxio.grpc.GetWorkerIdPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerIdPResponse
 
PARSER - Static variable in class alluxio.grpc.GetWorkerInfoListPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerInfoListPOptions
 
PARSER - Static variable in class alluxio.grpc.GetWorkerInfoListPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerInfoListPResponse
 
PARSER - Static variable in class alluxio.grpc.GetWorkerLostStoragePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
PARSER - Static variable in class alluxio.grpc.GetWorkerLostStoragePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
PARSER - Static variable in class alluxio.grpc.GetWorkerReportPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.GetWorkerReportPOptions
 
PARSER - Static variable in class alluxio.grpc.InconsistentProperties
Deprecated.
parser() - Static method in class alluxio.grpc.InconsistentProperties
 
PARSER - Static variable in class alluxio.grpc.InconsistentProperty
Deprecated.
parser() - Static method in class alluxio.grpc.InconsistentProperty
 
PARSER - Static variable in class alluxio.grpc.InconsistentPropertyValues
Deprecated.
parser() - Static method in class alluxio.grpc.InconsistentPropertyValues
 
PARSER - Static variable in class alluxio.grpc.JobCommand
Deprecated.
parser() - Static method in class alluxio.grpc.JobCommand
 
PARSER - Static variable in class alluxio.grpc.JobDescription
Deprecated.
parser() - Static method in class alluxio.grpc.JobDescription
 
PARSER - Static variable in class alluxio.grpc.JobHeartbeatPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.JobHeartbeatPOptions
 
PARSER - Static variable in class alluxio.grpc.JobHeartbeatPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.JobHeartbeatPRequest
 
PARSER - Static variable in class alluxio.grpc.JobHeartbeatPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.JobHeartbeatPResponse
 
PARSER - Static variable in class alluxio.grpc.JobInfo
Deprecated.
parser() - Static method in class alluxio.grpc.JobInfo
 
PARSER - Static variable in class alluxio.grpc.JobMasterHeartbeatPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
PARSER - Static variable in class alluxio.grpc.JobMasterHeartbeatPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
PARSER - Static variable in class alluxio.grpc.JobMasterHeartbeatPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
PARSER - Static variable in class alluxio.grpc.JobMasterStatus
Deprecated.
parser() - Static method in class alluxio.grpc.JobMasterStatus
 
PARSER - Static variable in class alluxio.grpc.JobProgress
Deprecated.
parser() - Static method in class alluxio.grpc.JobProgress
 
PARSER - Static variable in class alluxio.grpc.JobProgressPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.JobProgressPOptions
 
PARSER - Static variable in class alluxio.grpc.JobServiceSummary
Deprecated.
parser() - Static method in class alluxio.grpc.JobServiceSummary
 
PARSER - Static variable in class alluxio.grpc.JobStatusBlock
Deprecated.
parser() - Static method in class alluxio.grpc.JobStatusBlock
 
PARSER - Static variable in class alluxio.grpc.JobUnused
Deprecated.
parser() - Static method in class alluxio.grpc.JobUnused
 
PARSER - Static variable in class alluxio.grpc.JobWorkerHealth
Deprecated.
parser() - Static method in class alluxio.grpc.JobWorkerHealth
 
PARSER - Static variable in class alluxio.grpc.JournalQueryRequest
Deprecated.
parser() - Static method in class alluxio.grpc.JournalQueryRequest
 
PARSER - Static variable in class alluxio.grpc.JournalQueryResponse
Deprecated.
parser() - Static method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.LatestSnapshotInfoPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
PARSER - Static variable in class alluxio.grpc.ListAllPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ListAllPOptions
 
PARSER - Static variable in class alluxio.grpc.ListAllPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ListAllPRequest
 
PARSER - Static variable in class alluxio.grpc.ListAllPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ListAllPResponse
 
PARSER - Static variable in class alluxio.grpc.ListPolicyPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ListPolicyPOptions
 
PARSER - Static variable in class alluxio.grpc.ListPolicyPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ListPolicyPRequest
 
PARSER - Static variable in class alluxio.grpc.ListPolicyPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ListPolicyPResponse
 
PARSER - Static variable in class alluxio.grpc.ListProxyStatusPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ListProxyStatusPOptions
 
PARSER - Static variable in class alluxio.grpc.ListProxyStatusPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ListProxyStatusPRequest
 
PARSER - Static variable in class alluxio.grpc.ListProxyStatusPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ListProxyStatusPResponse
 
PARSER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ListStatusPartialPOptions
 
PARSER - Static variable in class alluxio.grpc.ListStatusPartialPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ListStatusPartialPRequest
 
PARSER - Static variable in class alluxio.grpc.ListStatusPartialPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ListStatusPartialPResponse
 
PARSER - Static variable in class alluxio.grpc.ListStatusPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ListStatusPOptions
 
PARSER - Static variable in class alluxio.grpc.ListStatusPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ListStatusPRequest
 
PARSER - Static variable in class alluxio.grpc.ListStatusPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ListStatusPResponse
 
PARSER - Static variable in class alluxio.grpc.LoadFileFailure
Deprecated.
parser() - Static method in class alluxio.grpc.LoadFileFailure
 
PARSER - Static variable in class alluxio.grpc.LoadFileRequest
Deprecated.
parser() - Static method in class alluxio.grpc.LoadFileRequest
 
PARSER - Static variable in class alluxio.grpc.LoadFileResponse
Deprecated.
parser() - Static method in class alluxio.grpc.LoadFileResponse
 
PARSER - Static variable in class alluxio.grpc.LoadJobPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.LoadJobPOptions
 
PARSER - Static variable in class alluxio.grpc.LoadMetadataPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.LoadMetadataPOptions
 
PARSER - Static variable in class alluxio.grpc.LoadRequest
Deprecated.
parser() - Static method in class alluxio.grpc.LoadRequest
 
PARSER - Static variable in class alluxio.grpc.LoadResponse
Deprecated.
parser() - Static method in class alluxio.grpc.LoadResponse
 
PARSER - Static variable in class alluxio.grpc.LocationBlockIdListEntry
Deprecated.
parser() - Static method in class alluxio.grpc.LocationBlockIdListEntry
 
PARSER - Static variable in class alluxio.grpc.MasterHeartbeatPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.MasterHeartbeatPOptions
 
PARSER - Static variable in class alluxio.grpc.MasterHeartbeatPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.MasterHeartbeatPRequest
 
PARSER - Static variable in class alluxio.grpc.MasterHeartbeatPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.MasterHeartbeatPResponse
 
PARSER - Static variable in class alluxio.grpc.MasterInfo
Deprecated.
parser() - Static method in class alluxio.grpc.MasterInfo
 
PARSER - Static variable in class alluxio.grpc.MasterVersion
Deprecated.
parser() - Static method in class alluxio.grpc.MasterVersion
 
PARSER - Static variable in class alluxio.grpc.MessagingRequestHeader
Deprecated.
parser() - Static method in class alluxio.grpc.MessagingRequestHeader
 
PARSER - Static variable in class alluxio.grpc.MessagingResponseHeader
Deprecated.
parser() - Static method in class alluxio.grpc.MessagingResponseHeader
 
PARSER - Static variable in class alluxio.grpc.Metric
Deprecated.
parser() - Static method in class alluxio.grpc.Metric
 
PARSER - Static variable in class alluxio.grpc.MetricsHeartbeatPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.MetricsHeartbeatPOptions
 
PARSER - Static variable in class alluxio.grpc.MetricsHeartbeatPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.MetricsHeartbeatPRequest
 
PARSER - Static variable in class alluxio.grpc.MetricsHeartbeatPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.MetricsHeartbeatPResponse
 
PARSER - Static variable in class alluxio.grpc.MetricValue
Deprecated.
parser() - Static method in class alluxio.grpc.MetricValue
 
PARSER - Static variable in class alluxio.grpc.MountPointInfo
Deprecated.
parser() - Static method in class alluxio.grpc.MountPointInfo
 
PARSER - Static variable in class alluxio.grpc.MountPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.MountPOptions
 
PARSER - Static variable in class alluxio.grpc.MountPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.MountPRequest
 
PARSER - Static variable in class alluxio.grpc.MountPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.MountPResponse
 
PARSER - Static variable in class alluxio.grpc.MoveBlockRequest
Deprecated.
parser() - Static method in class alluxio.grpc.MoveBlockRequest
 
PARSER - Static variable in class alluxio.grpc.MoveBlockResponse
Deprecated.
parser() - Static method in class alluxio.grpc.MoveBlockResponse
 
PARSER - Static variable in class alluxio.grpc.MoveJobPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.MoveJobPOptions
 
PARSER - Static variable in class alluxio.grpc.MoveRequest
Deprecated.
parser() - Static method in class alluxio.grpc.MoveRequest
 
PARSER - Static variable in class alluxio.grpc.MoveResponse
Deprecated.
parser() - Static method in class alluxio.grpc.MoveResponse
 
PARSER - Static variable in class alluxio.grpc.NeedsSyncRequest
Deprecated.
parser() - Static method in class alluxio.grpc.NeedsSyncRequest
 
PARSER - Static variable in class alluxio.grpc.NeedsSyncResponse
Deprecated.
parser() - Static method in class alluxio.grpc.NeedsSyncResponse
 
PARSER - Static variable in class alluxio.grpc.NetAddress
Deprecated.
parser() - Static method in class alluxio.grpc.NetAddress
 
PARSER - Static variable in class alluxio.grpc.NotifyWorkerIdPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.NotifyWorkerIdPOptions
 
PARSER - Static variable in class alluxio.grpc.NotifyWorkerIdPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.NotifyWorkerIdPRequest
 
PARSER - Static variable in class alluxio.grpc.NotifyWorkerIdPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.NotifyWorkerIdPResponse
 
PARSER - Static variable in class alluxio.grpc.OpenFilePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.OpenFilePOptions
 
PARSER - Static variable in class alluxio.grpc.PAcl
Deprecated.
parser() - Static method in class alluxio.grpc.PAcl
 
PARSER - Static variable in class alluxio.grpc.PAclEntry
Deprecated.
parser() - Static method in class alluxio.grpc.PAclEntry
 
PARSER - Static variable in class alluxio.grpc.PersistCommandOptions
Deprecated.
parser() - Static method in class alluxio.grpc.PersistCommandOptions
 
PARSER - Static variable in class alluxio.grpc.PersistFile
Deprecated.
parser() - Static method in class alluxio.grpc.PersistFile
 
PARSER - Static variable in class alluxio.grpc.PMode
Deprecated.
parser() - Static method in class alluxio.grpc.PMode
 
PARSER - Static variable in class alluxio.grpc.PolicyInfo
Deprecated.
parser() - Static method in class alluxio.grpc.PolicyInfo
 
PARSER - Static variable in class alluxio.grpc.PolicyStatus
Deprecated.
parser() - Static method in class alluxio.grpc.PolicyStatus
 
PARSER - Static variable in class alluxio.grpc.ProxyHeartbeatPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ProxyHeartbeatPOptions
 
PARSER - Static variable in class alluxio.grpc.ProxyHeartbeatPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ProxyHeartbeatPRequest
 
PARSER - Static variable in class alluxio.grpc.ProxyHeartbeatPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ProxyHeartbeatPResponse
 
PARSER - Static variable in class alluxio.grpc.ProxyStatus
Deprecated.
parser() - Static method in class alluxio.grpc.ProxyStatus
 
PARSER - Static variable in class alluxio.grpc.QuorumServerInfo
Deprecated.
parser() - Static method in class alluxio.grpc.QuorumServerInfo
 
PARSER - Static variable in class alluxio.grpc.ReadRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ReadRequest
 
PARSER - Static variable in class alluxio.grpc.ReadResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ReadResponse
 
PARSER - Static variable in class alluxio.grpc.RegisterCommand
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterCommand
 
PARSER - Static variable in class alluxio.grpc.RegisterJobMasterPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterJobMasterPOptions
 
PARSER - Static variable in class alluxio.grpc.RegisterJobMasterPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterJobMasterPRequest
 
PARSER - Static variable in class alluxio.grpc.RegisterJobMasterPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterJobMasterPResponse
 
PARSER - Static variable in class alluxio.grpc.RegisterJobWorkerPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterJobWorkerPOptions
 
PARSER - Static variable in class alluxio.grpc.RegisterJobWorkerPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterJobWorkerPRequest
 
PARSER - Static variable in class alluxio.grpc.RegisterJobWorkerPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterJobWorkerPResponse
 
PARSER - Static variable in class alluxio.grpc.RegisterMasterPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterMasterPOptions
 
PARSER - Static variable in class alluxio.grpc.RegisterMasterPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterMasterPRequest
 
PARSER - Static variable in class alluxio.grpc.RegisterMasterPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterMasterPResponse
 
PARSER - Static variable in class alluxio.grpc.RegisterWorkerPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterWorkerPOptions
 
PARSER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterWorkerPRequest
 
PARSER - Static variable in class alluxio.grpc.RegisterWorkerPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RegisterWorkerPResponse
 
PARSER - Static variable in class alluxio.grpc.RemoveBlockRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RemoveBlockRequest
 
PARSER - Static variable in class alluxio.grpc.RemoveBlockResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RemoveBlockResponse
 
PARSER - Static variable in class alluxio.grpc.RemoveDisabledWorkerPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
PARSER - Static variable in class alluxio.grpc.RemoveDisabledWorkerPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
PARSER - Static variable in class alluxio.grpc.RemovePathConfigurationPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RemovePathConfigurationPOptions
 
PARSER - Static variable in class alluxio.grpc.RemovePathConfigurationPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RemovePathConfigurationPRequest
 
PARSER - Static variable in class alluxio.grpc.RemovePathConfigurationPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RemovePathConfigurationPResponse
 
PARSER - Static variable in class alluxio.grpc.RemovePolicyPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RemovePolicyPOptions
 
PARSER - Static variable in class alluxio.grpc.RemovePolicyPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RemovePolicyPRequest
 
PARSER - Static variable in class alluxio.grpc.RemovePolicyPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RemovePolicyPResponse
 
PARSER - Static variable in class alluxio.grpc.RemoveQuorumServerPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RemoveQuorumServerPOptions
 
PARSER - Static variable in class alluxio.grpc.RemoveQuorumServerPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RemoveQuorumServerPRequest
 
PARSER - Static variable in class alluxio.grpc.RemoveQuorumServerPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RemoveQuorumServerPResponse
 
PARSER - Static variable in class alluxio.grpc.RenamePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RenamePOptions
 
PARSER - Static variable in class alluxio.grpc.RenamePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RenamePRequest
 
PARSER - Static variable in class alluxio.grpc.RenamePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RenamePResponse
 
PARSER - Static variable in class alluxio.grpc.ResetPrioritiesPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ResetPrioritiesPOptions
 
PARSER - Static variable in class alluxio.grpc.ResetPrioritiesPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ResetPrioritiesPRequest
 
PARSER - Static variable in class alluxio.grpc.ResetPrioritiesPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ResetPrioritiesPResponse
 
PARSER - Static variable in class alluxio.grpc.RetryInfo
Deprecated.
parser() - Static method in class alluxio.grpc.RetryInfo
 
PARSER - Static variable in class alluxio.grpc.ReverseResolvePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ReverseResolvePRequest
 
PARSER - Static variable in class alluxio.grpc.ReverseResolvePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ReverseResolvePResponse
 
PARSER - Static variable in class alluxio.grpc.Route
Deprecated.
parser() - Static method in class alluxio.grpc.Route
 
PARSER - Static variable in class alluxio.grpc.RouteFailure
Deprecated.
parser() - Static method in class alluxio.grpc.RouteFailure
 
PARSER - Static variable in class alluxio.grpc.RunPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.RunPOptions
 
PARSER - Static variable in class alluxio.grpc.RunPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.RunPRequest
 
PARSER - Static variable in class alluxio.grpc.RunPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.RunPResponse
 
PARSER - Static variable in class alluxio.grpc.RunTaskCommand
Deprecated.
parser() - Static method in class alluxio.grpc.RunTaskCommand
 
PARSER - Static variable in class alluxio.grpc.S3SyntaxOptions
Deprecated.
parser() - Static method in class alluxio.grpc.S3SyntaxOptions
 
PARSER - Static variable in class alluxio.grpc.SaslMessage
Deprecated.
parser() - Static method in class alluxio.grpc.SaslMessage
 
PARSER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
PARSER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
PARSER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
PARSER - Static variable in class alluxio.grpc.SetAclPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.SetAclPOptions
 
PARSER - Static variable in class alluxio.grpc.SetAclPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.SetAclPRequest
 
PARSER - Static variable in class alluxio.grpc.SetAclPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.SetAclPResponse
 
PARSER - Static variable in class alluxio.grpc.SetAttributePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.SetAttributePOptions
 
PARSER - Static variable in class alluxio.grpc.SetAttributePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.SetAttributePRequest
 
PARSER - Static variable in class alluxio.grpc.SetAttributePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.SetAttributePResponse
 
PARSER - Static variable in class alluxio.grpc.SetPathConfigurationPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.SetPathConfigurationPOptions
 
PARSER - Static variable in class alluxio.grpc.SetPathConfigurationPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.SetPathConfigurationPRequest
 
PARSER - Static variable in class alluxio.grpc.SetPathConfigurationPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.SetPathConfigurationPResponse
 
PARSER - Static variable in class alluxio.grpc.SetTaskPoolSizeCommand
Deprecated.
parser() - Static method in class alluxio.grpc.SetTaskPoolSizeCommand
 
PARSER - Static variable in class alluxio.grpc.SnapshotData
Deprecated.
parser() - Static method in class alluxio.grpc.SnapshotData
 
PARSER - Static variable in class alluxio.grpc.SnapshotMetadata
Deprecated.
parser() - Static method in class alluxio.grpc.SnapshotMetadata
 
PARSER - Static variable in class alluxio.grpc.StatusSummary
Deprecated.
parser() - Static method in class alluxio.grpc.StatusSummary
 
PARSER - Static variable in class alluxio.grpc.StopJobPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.StopJobPRequest
 
PARSER - Static variable in class alluxio.grpc.StopJobPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.StopJobPResponse
 
PARSER - Static variable in class alluxio.grpc.StorageList
Deprecated.
parser() - Static method in class alluxio.grpc.StorageList
 
PARSER - Static variable in class alluxio.grpc.SubmitJobPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.SubmitJobPRequest
 
PARSER - Static variable in class alluxio.grpc.SubmitJobPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.SubmitJobPResponse
 
PARSER - Static variable in class alluxio.grpc.SubmitOptions
Deprecated.
parser() - Static method in class alluxio.grpc.SubmitOptions
 
PARSER - Static variable in class alluxio.grpc.SubmitRequest
Deprecated.
parser() - Static method in class alluxio.grpc.SubmitRequest
 
PARSER - Static variable in class alluxio.grpc.SubmitResponse
Deprecated.
parser() - Static method in class alluxio.grpc.SubmitResponse
 
PARSER - Static variable in class alluxio.grpc.table.AllOrNoneSet
Deprecated.
parser() - Static method in class alluxio.grpc.table.AllOrNoneSet
 
PARSER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.AttachDatabasePRequest
 
PARSER - Static variable in class alluxio.grpc.table.AttachDatabasePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.AttachDatabasePResponse
 
PARSER - Static variable in class alluxio.grpc.table.BinaryColumnStatsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.BinaryColumnStatsData
 
PARSER - Static variable in class alluxio.grpc.table.BooleanColumnStatsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.BooleanColumnStatsData
 
PARSER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.ColumnStatisticsData
 
PARSER - Static variable in class alluxio.grpc.table.ColumnStatisticsInfo
Deprecated.
parser() - Static method in class alluxio.grpc.table.ColumnStatisticsInfo
 
PARSER - Static variable in class alluxio.grpc.table.ColumnStatisticsList
Deprecated.
parser() - Static method in class alluxio.grpc.table.ColumnStatisticsList
 
PARSER - Static variable in class alluxio.grpc.table.Constraint
Deprecated.
parser() - Static method in class alluxio.grpc.table.Constraint
 
PARSER - Static variable in class alluxio.grpc.table.Database
Deprecated.
parser() - Static method in class alluxio.grpc.table.Database
 
PARSER - Static variable in class alluxio.grpc.table.Date
Deprecated.
parser() - Static method in class alluxio.grpc.table.Date
 
PARSER - Static variable in class alluxio.grpc.table.DateColumnStatsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.DateColumnStatsData
 
PARSER - Static variable in class alluxio.grpc.table.Decimal
Deprecated.
parser() - Static method in class alluxio.grpc.table.Decimal
 
PARSER - Static variable in class alluxio.grpc.table.DecimalColumnStatsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.DecimalColumnStatsData
 
PARSER - Static variable in class alluxio.grpc.table.DetachDatabasePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.DetachDatabasePRequest
 
PARSER - Static variable in class alluxio.grpc.table.DetachDatabasePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.DetachDatabasePResponse
 
PARSER - Static variable in class alluxio.grpc.table.Domain
Deprecated.
parser() - Static method in class alluxio.grpc.table.Domain
 
PARSER - Static variable in class alluxio.grpc.table.DoubleColumnStatsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.DoubleColumnStatsData
 
PARSER - Static variable in class alluxio.grpc.table.EquatableValueSet
Deprecated.
parser() - Static method in class alluxio.grpc.table.EquatableValueSet
 
PARSER - Static variable in class alluxio.grpc.table.FieldSchema
Deprecated.
parser() - Static method in class alluxio.grpc.table.FieldSchema
 
PARSER - Static variable in class alluxio.grpc.table.FileStatistics
Deprecated.
parser() - Static method in class alluxio.grpc.table.FileStatistics
 
PARSER - Static variable in class alluxio.grpc.table.GetAllDatabasesPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
PARSER - Static variable in class alluxio.grpc.table.GetAllDatabasesPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
PARSER - Static variable in class alluxio.grpc.table.GetAllTablesPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetAllTablesPRequest
 
PARSER - Static variable in class alluxio.grpc.table.GetAllTablesPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetAllTablesPResponse
 
PARSER - Static variable in class alluxio.grpc.table.GetDatabasePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetDatabasePRequest
 
PARSER - Static variable in class alluxio.grpc.table.GetDatabasePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetDatabasePResponse
 
PARSER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
PARSER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
PARSER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
PARSER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
PARSER - Static variable in class alluxio.grpc.table.GetTablePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetTablePRequest
 
PARSER - Static variable in class alluxio.grpc.table.GetTablePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetTablePResponse
 
PARSER - Static variable in class alluxio.grpc.table.GetTransformJobInfoPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
PARSER - Static variable in class alluxio.grpc.table.GetTransformJobInfoPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
PARSER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
Deprecated.
parser() - Static method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
PARSER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
Deprecated.
parser() - Static method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
PARSER - Static variable in class alluxio.grpc.table.layout.hive.SortingColumn
Deprecated.
parser() - Static method in class alluxio.grpc.table.layout.hive.SortingColumn
 
PARSER - Static variable in class alluxio.grpc.table.layout.hive.Storage
Deprecated.
parser() - Static method in class alluxio.grpc.table.layout.hive.Storage
 
PARSER - Static variable in class alluxio.grpc.table.layout.hive.StorageFormat
Deprecated.
parser() - Static method in class alluxio.grpc.table.layout.hive.StorageFormat
 
PARSER - Static variable in class alluxio.grpc.table.Layout
Deprecated.
parser() - Static method in class alluxio.grpc.table.Layout
 
PARSER - Static variable in class alluxio.grpc.table.LayoutSpec
Deprecated.
parser() - Static method in class alluxio.grpc.table.LayoutSpec
 
PARSER - Static variable in class alluxio.grpc.table.LongColumnStatsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.LongColumnStatsData
 
PARSER - Static variable in class alluxio.grpc.table.Partition
Deprecated.
parser() - Static method in class alluxio.grpc.table.Partition
 
PARSER - Static variable in class alluxio.grpc.table.PartitionSpec
Deprecated.
parser() - Static method in class alluxio.grpc.table.PartitionSpec
 
PARSER - Static variable in class alluxio.grpc.table.Range
Deprecated.
parser() - Static method in class alluxio.grpc.table.Range
 
PARSER - Static variable in class alluxio.grpc.table.RangeSet
Deprecated.
parser() - Static method in class alluxio.grpc.table.RangeSet
 
PARSER - Static variable in class alluxio.grpc.table.ReadTablePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.ReadTablePRequest
 
PARSER - Static variable in class alluxio.grpc.table.ReadTablePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.ReadTablePResponse
 
PARSER - Static variable in class alluxio.grpc.table.Schema
Deprecated.
parser() - Static method in class alluxio.grpc.table.Schema
 
PARSER - Static variable in class alluxio.grpc.table.StringColumnStatsData
Deprecated.
parser() - Static method in class alluxio.grpc.table.StringColumnStatsData
 
PARSER - Static variable in class alluxio.grpc.table.SyncDatabasePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.SyncDatabasePRequest
 
PARSER - Static variable in class alluxio.grpc.table.SyncDatabasePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.SyncDatabasePResponse
 
PARSER - Static variable in class alluxio.grpc.table.SyncStatus
Deprecated.
parser() - Static method in class alluxio.grpc.table.SyncStatus
 
PARSER - Static variable in class alluxio.grpc.table.TableInfo
Deprecated.
parser() - Static method in class alluxio.grpc.table.TableInfo
 
PARSER - Static variable in class alluxio.grpc.table.Transformation
Deprecated.
parser() - Static method in class alluxio.grpc.table.Transformation
 
PARSER - Static variable in class alluxio.grpc.table.TransformJobInfo
Deprecated.
parser() - Static method in class alluxio.grpc.table.TransformJobInfo
 
PARSER - Static variable in class alluxio.grpc.table.TransformTablePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.table.TransformTablePRequest
 
PARSER - Static variable in class alluxio.grpc.table.TransformTablePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.table.TransformTablePResponse
 
PARSER - Static variable in class alluxio.grpc.table.Value
Deprecated.
parser() - Static method in class alluxio.grpc.table.Value
 
PARSER - Static variable in class alluxio.grpc.TierList
Deprecated.
parser() - Static method in class alluxio.grpc.TierList
 
PARSER - Static variable in class alluxio.grpc.TransferLeaderMessage
Deprecated.
parser() - Static method in class alluxio.grpc.TransferLeaderMessage
 
PARSER - Static variable in class alluxio.grpc.TransferLeadershipPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.TransferLeadershipPOptions
 
PARSER - Static variable in class alluxio.grpc.TransferLeadershipPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.TransferLeadershipPRequest
 
PARSER - Static variable in class alluxio.grpc.TransferLeadershipPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.TransferLeadershipPResponse
 
PARSER - Static variable in class alluxio.grpc.TransportMessage
Deprecated.
parser() - Static method in class alluxio.grpc.TransportMessage
 
PARSER - Static variable in class alluxio.grpc.TriggerPolicyRequest
Deprecated.
parser() - Static method in class alluxio.grpc.TriggerPolicyRequest
 
PARSER - Static variable in class alluxio.grpc.TriggerPolicyResponse
Deprecated.
parser() - Static method in class alluxio.grpc.TriggerPolicyResponse
 
PARSER - Static variable in class alluxio.grpc.UfsFileStatus
Deprecated.
parser() - Static method in class alluxio.grpc.UfsFileStatus
 
PARSER - Static variable in class alluxio.grpc.UfsInfo
Deprecated.
parser() - Static method in class alluxio.grpc.UfsInfo
 
PARSER - Static variable in class alluxio.grpc.UfsReadOptions
Deprecated.
parser() - Static method in class alluxio.grpc.UfsReadOptions
 
PARSER - Static variable in class alluxio.grpc.UfsStatus
Deprecated.
parser() - Static method in class alluxio.grpc.UfsStatus
 
PARSER - Static variable in class alluxio.grpc.UnmountPOptions
Deprecated.
parser() - Static method in class alluxio.grpc.UnmountPOptions
 
PARSER - Static variable in class alluxio.grpc.UnmountPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.UnmountPRequest
 
PARSER - Static variable in class alluxio.grpc.UnmountPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.UnmountPResponse
 
PARSER - Static variable in class alluxio.grpc.UpdateConfigurationPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.UpdateConfigurationPRequest
 
PARSER - Static variable in class alluxio.grpc.UpdateConfigurationPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.UpdateConfigurationPResponse
 
PARSER - Static variable in class alluxio.grpc.UpdateMountPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.UpdateMountPRequest
 
PARSER - Static variable in class alluxio.grpc.UpdateMountPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.UpdateMountPResponse
 
PARSER - Static variable in class alluxio.grpc.UpdateUfsModePOptions
Deprecated.
parser() - Static method in class alluxio.grpc.UpdateUfsModePOptions
 
PARSER - Static variable in class alluxio.grpc.UpdateUfsModePRequest
Deprecated.
parser() - Static method in class alluxio.grpc.UpdateUfsModePRequest
 
PARSER - Static variable in class alluxio.grpc.UpdateUfsModePResponse
Deprecated.
parser() - Static method in class alluxio.grpc.UpdateUfsModePResponse
 
PARSER - Static variable in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
parser() - Static method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
parser() - Static method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
PARSER - Static variable in class alluxio.grpc.WorkerIdentity
Deprecated.
parser() - Static method in class alluxio.grpc.WorkerIdentity
 
PARSER - Static variable in class alluxio.grpc.WorkerInfo
Deprecated.
parser() - Static method in class alluxio.grpc.WorkerInfo
 
PARSER - Static variable in class alluxio.grpc.WorkerLostStorageInfo
Deprecated.
parser() - Static method in class alluxio.grpc.WorkerLostStorageInfo
 
PARSER - Static variable in class alluxio.grpc.WorkerNetAddress
Deprecated.
parser() - Static method in class alluxio.grpc.WorkerNetAddress
 
PARSER - Static variable in class alluxio.grpc.WriteOptions
Deprecated.
parser() - Static method in class alluxio.grpc.WriteOptions
 
PARSER - Static variable in class alluxio.grpc.WriteRequest
Deprecated.
parser() - Static method in class alluxio.grpc.WriteRequest
 
PARSER - Static variable in class alluxio.grpc.WriteRequestCommand
Deprecated.
parser() - Static method in class alluxio.grpc.WriteRequestCommand
 
PARSER - Static variable in class alluxio.grpc.WriteResponse
Deprecated.
parser() - Static method in class alluxio.grpc.WriteResponse
 
PARSER - Static variable in class alluxio.proto.client.Cache.PPageStoreCommonOptions
Deprecated.
parser() - Static method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
PARSER - Static variable in class alluxio.proto.client.Cache.PRocksPageStoreOptions
Deprecated.
parser() - Static method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.Heartbeat
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.ReadResponse
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.Response
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.Response
 
PARSER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
Deprecated.
parser() - Static method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
PARSER - Static variable in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
PARSER - Static variable in class alluxio.proto.journal.Block.BlockInfoEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Block.BlockInfoEntry
 
PARSER - Static variable in class alluxio.proto.journal.Block.DeleteBlockEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.AddMountPointEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.AddSyncPointEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.AddSyncPointEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.AsyncPersistRequestEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.CompleteFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.DeleteFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.DeleteMountPointEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.InodeFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.NewBlockEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.NewBlockEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.PersistDirectoryEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.PersistFileEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.PersistFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.RemoveSyncPointEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.RenameEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.RenameEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.SetAclEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.SetAclEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.SetAttributeEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.StringPairEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.StringPairEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.UpdateInodeEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
PARSER - Static variable in class alluxio.proto.journal.File.UpdateUfsModeEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
PARSER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Job.CopyJobEntry
 
PARSER - Static variable in class alluxio.proto.journal.Job.FileFilter
Deprecated.
parser() - Static method in class alluxio.proto.journal.Job.FileFilter
 
PARSER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Job.LoadJobEntry
 
PARSER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Job.MoveJobEntry
 
PARSER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Journal.JournalEntry
 
PARSER - Static variable in class alluxio.proto.journal.Journal.JournalOpPId
Deprecated.
parser() - Static method in class alluxio.proto.journal.Journal.JournalOpPId
 
PARSER - Static variable in class alluxio.proto.journal.Meta.ClusterInfoEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
PARSER - Static variable in class alluxio.proto.journal.Meta.PathPropertiesEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
PARSER - Static variable in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
PARSER - Static variable in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
PARSER - Static variable in class alluxio.proto.journal.Policy.PolicyRemoveEntry
Deprecated.
parser() - Static method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
PARSER - Static variable in class alluxio.proto.meta.Block.BlockLocation
Deprecated.
parser() - Static method in class alluxio.proto.meta.Block.BlockLocation
 
PARSER - Static variable in class alluxio.proto.meta.Block.BlockMeta
Deprecated.
parser() - Static method in class alluxio.proto.meta.Block.BlockMeta
 
PARSER - Static variable in class alluxio.proto.meta.DoraMeta.FileStatus
Deprecated.
parser() - Static method in class alluxio.proto.meta.DoraMeta.FileStatus
 
PARSER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
Deprecated.
parser() - Static method in class alluxio.proto.meta.InodeMeta.Inode
 
PARSER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
Deprecated.
parser() - Static method in class alluxio.proto.shared.Acl.AccessControlList
 
PARSER - Static variable in class alluxio.proto.shared.Acl.AclActions
Deprecated.
parser() - Static method in class alluxio.proto.shared.Acl.AclActions
 
PARSER - Static variable in class alluxio.proto.shared.Acl.AclEntry
Deprecated.
parser() - Static method in class alluxio.proto.shared.Acl.AclEntry
 
PARSER - Static variable in class alluxio.proto.shared.Acl.NamedAclActions
Deprecated.
parser() - Static method in class alluxio.proto.shared.Acl.NamedAclActions
 
parseRequestParameters(String) - Static method in class alluxio.worker.http.HttpRequestUtil
Parse the parameters from the HTTP request URI and return a map of the parameters.
Parsers() - Constructor for class alluxio.wire.WorkerIdentity.Parsers
 
parseSignature() - Method in class alluxio.s3.signature.AwsSignatureProcessor
Extract signature info from request.
parseSignature(String) - Static method in class alluxio.s3.signature.utils.AwsAuthV2HeaderParserUtils
Function to parse signature.
parseSignature(String, String) - Static method in class alluxio.s3.signature.utils.AwsAuthV4HeaderParserUtils
Function to parse signature.
parseSignature(Map<String, String>) - Static method in class alluxio.s3.signature.utils.AwsAuthV4QueryParserUtils
Function to parse signature.
parseSpaceSize(String) - Static method in class alluxio.util.FormatUtils
Parses a String size to Bytes.
parseTimeSize(String) - Static method in class alluxio.util.FormatUtils
Parses a String size to Milliseconds.
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in interface alluxio.master.journal.checkpoint.CheckpointFormat
 
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in class alluxio.master.journal.checkpoint.CompoundCheckpointFormat
 
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in class alluxio.master.journal.checkpoint.InodeProtosCheckpointFormat
 
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in class alluxio.master.journal.checkpoint.JournalCheckpointFormat
 
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in class alluxio.master.journal.checkpoint.LongCheckpointFormat
 
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in class alluxio.master.journal.checkpoint.LongsCheckpointFormat
 
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in class alluxio.master.journal.checkpoint.TarballCheckpointFormat
 
parseToHumanReadable(CheckpointInputStream, PrintStream) - Method in class alluxio.master.journal.checkpoint.ZipCheckpointFormat
 
parseValue(String) - Method in class alluxio.conf.PropertyKey
Parses value from string.
parseVersion(String) - Method in class alluxio.cli.hdfs.HdfsVersionValidationTask
 
parseWorkerAddresses(String, AlluxioConfiguration) - Static method in class alluxio.cli.fsadmin.command.WorkerAddressUtils
Parses a string to worker addresses.
parseXmlConfiguration(String) - Method in class alluxio.cli.hdfs.HadoopConfigurationFileParser
Parse an xml configuration file into a map.
Part() - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
Part(String, int) - Constructor for class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
Part() - Constructor for class alluxio.proxy.s3.ListPartsResult.Part
Constructs a default ListPartsResult.Part.
PART_NAMES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
PARTIAL_FAILURE_VALUE - Static variable in enum alluxio.grpc.TaskStatus
PARTIAL_FAILURE = 2;
PARTIALLISTING_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyJobPOptions
 
PARTIALLISTING_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadJobPOptions
 
PARTIALLISTING_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveJobPOptions
 
PARTIALLISTING_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
PARTIALLISTING_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
PARTIALLISTING_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
PartialReadException - Exception in alluxio.client.file.dora.netty
Exception when a positioned read operation was incomplete due to an underlying exception occurred.
PartialReadException(int, int, PartialReadException.CauseType, Throwable) - Constructor for exception alluxio.client.file.dora.netty.PartialReadException
Constructor.
PartialReadException.CauseType - Enum in alluxio.client.file.dora.netty
Possible causes of PartialReadException.
Partition - Class in alluxio.grpc.table
next available id: 6
partition(List<T>, int) - Static method in class alluxio.util.CommonUtils
Partitions a list into numLists many lists each with around list.size() / numLists elements.
Partition.Builder - Class in alluxio.grpc.table
next available id: 6
PARTITION_COLS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
PARTITION_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
PARTITION_SPEC_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Partition
 
PARTITION_STATISTICS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
partitionedBy(CacheUsage.PartitionDescriptor<?>) - Method in interface alluxio.client.file.cache.CacheUsage
Gets a finer-grained view of cache usage.
partitionedBy(CacheUsage.PartitionDescriptor<?>) - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
partitionFieldNames(List<Parameters>) - Static method in class alluxio.stress.Parameters
 
PartitionInfo - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.PartitionInfo
PartitionInfo.Builder - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.PartitionInfo
PartitionInfoOrBuilder - Interface in alluxio.grpc.table.layout.hive
 
PartitionOrBuilder - Interface in alluxio.grpc.table
 
PARTITIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ReadTablePResponse
 
PartitionSpec - Class in alluxio.grpc.table
TODO(gpang): update
PartitionSpec.Builder - Class in alluxio.grpc.table
TODO(gpang): update
PartitionSpecOrBuilder - Interface in alluxio.grpc.table
 
PassAllAuthenticator - Class in alluxio.s3.auth
Default implementation of Authenticator.
PassAllAuthenticator() - Constructor for class alluxio.s3.auth.PassAllAuthenticator
 
PASSED_VALUE - Static variable in enum alluxio.grpc.ConfigStatus
PASSED = 1;
PatchedInputChunked - Class in alluxio.master.journal
A replacement for Kryo's InputChunked which properly handles eof.
PatchedInputChunked(InputStream) - Constructor for class alluxio.master.journal.PatchedInputChunked
 
PATH - Static variable in class alluxio.stress.worker.UfsIOParameters
 
PATH_DEFAULT - Static variable in class alluxio.conf.Source
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckAccessPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckConsistencyPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.ExistsPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetFilePathPResponse
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.JobDescription
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.NeedsSyncRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.RemovePathConfigurationPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.SetPathConfigurationPRequest
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RenameEntry
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
PATH_INDEX - Static variable in class alluxio.fuse.AlluxioJniFuseFileSystem
 
PATH_PARAM - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
PATH_PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
PATH_SEPARATOR - Static variable in interface alluxio.membership.MembershipManager
 
PATH_SEPARATOR - Static variable in class alluxio.underfs.ObjectUnderFileSystem
Value used to indicate nested structure.
PATH_SEPARATOR_CHAR - Static variable in class alluxio.underfs.ObjectUnderFileSystem
Value used to indicate nested structure.
PATH_STRING_COMPARE - Static variable in class alluxio.util.webui.UIFileInfo
Provides ordering of UIFileInfo based off a string comparison of the absolute paths.
PATH_TRAVERSAL_RETRIES - Static variable in class alluxio.master.file.meta.InodeTree
Number of retries when trying to lock a path, from a given id.
PATHCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigHashPResponse
 
PATHCONFIGHASH_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
PATHCONFIGLASTUPDATETIME_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
PATHCONFIGS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPResponse
 
PathProperties - Class in alluxio.master.meta
Source of truth for path level properties.
PathProperties() - Constructor for class alluxio.master.meta.PathProperties
 
PathProperties.State - Class in alluxio.master.meta
Journaled state of path level properties.
PathPropertiesView - Class in alluxio.master.meta
Read-only view of path level properties.
PathPropertiesView(Map<String, Map<String, String>>, String, long) - Constructor for class alluxio.master.meta.PathPropertiesView
Constructs a read-only view of path level properties.
PathsRestServiceHandler - Class in alluxio.proxy
This class is a REST handler for path resources.
PathsRestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.PathsRestServiceHandler
Constructs a new PathsRestServiceHandler.
PathUtils - Class in alluxio.util.io
Utilities related to both Alluxio paths like AlluxioURI and local file paths.
PATTERN_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.FileFilter
 
PausableThreadPoolExecutor - Class in alluxio.worker.job.task
ThreadPoolExecutor that can be temporarily paused to prevent any threads from executing new tasks.
PausableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class alluxio.worker.job.task.PausableThreadPoolExecutor
Copy of one of the constructors in ThreadPoolExecutor.
pause() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
pause() - Method in class alluxio.worker.job.task.PausableThreadPoolExecutor
Pause all threads from executing new tasks.
PB - Static variable in class alluxio.Constants
 
peek() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
peekDirectoryId() - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
peekNewContainerId() - Method in class alluxio.master.block.BlockContainerIdGenerator
 
peekNextLocalTask() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns, but does not unschedule or execute, a task queued by the current thread but not yet executed, if one is immediately available.
Performance - Class in alluxio.examples
Example to show the performance of Alluxio.
Performance.AlluxioReadWorker - Class in alluxio.examples
A worker in Alluxio for read operations.
Performance.AlluxioWriterWorker - Class in alluxio.examples
A worker in Alluxio for write operations.
Performance.GeneralWorker - Class in alluxio.examples
A general worker.
Performance.HdfsWorker - Class in alluxio.examples
A worker for HDFS.
Performance.Worker - Class in alluxio.examples
Base class for workers used in this example.
performListingAsync(String, String, String, DescendantType, boolean, Consumer<UfsLoadResult>, Consumer<Throwable>) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
performListingAsync(String, String, String, DescendantType, boolean, Consumer<UfsLoadResult>, Consumer<Throwable>) - Method in interface alluxio.underfs.AsyncUfsClient
Lists the ufs statuses for a given path.
performListingAsync(String, String, String, DescendantType, boolean, Consumer<UfsLoadResult>, Consumer<Throwable>) - Method in class alluxio.underfs.BaseUnderFileSystem
 
performListingAsync(String, String, String, DescendantType, boolean, Consumer<UfsLoadResult>, Consumer<Throwable>) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
performListingAsync(String, String, String, DescendantType, boolean, Consumer<UfsLoadResult>, Consumer<Throwable>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
PERMISSION_DENIED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
PermissionDenied indicates the caller does not have permission to execute the specified operation.
PERMISSION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PermissionChecker - Interface in alluxio.master.file
interface to provide permission check logic.
PermissionDeniedException - Exception in alluxio.exception.status
Exception indicating that the caller does not have permission to execute the specified operation.
PermissionDeniedException(String) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedException(Throwable) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedException(String, Throwable) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the caller does not have permission to execute the specified operation.
PermissionDeniedRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.PermissionDeniedRuntimeException
Constructor.
permitKeepAlive(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the high-bar for client-side keep-alive frequency.
persist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
persist(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
persist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in interface alluxio.client.file.FileSystem
Schedules the given path to be asynchronously persisted to the under file system.
persist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
persist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
PERSIST_DIRECTORY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
PERSIST_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePOptions
 
PERSIST_JOB_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PERSIST_JOB_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
PERSIST_JOB_ID_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
PERSIST_JOB_TEMP_UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
Persist_VALUE - Static variable in enum alluxio.grpc.CommandType
Ask the worker to persist a file for lineage
PERSIST_VALUE - Static variable in enum alluxio.grpc.OperationType
PERSIST = 3;
persistAndWait(FileSystem, AlluxioURI, long) - Static method in class alluxio.client.file.FileSystemUtils
Convenience method for #persistAndWait(fs, uri, persistenceWaitTime, -1).
persistAndWait(FileSystem, AlluxioURI, long, int) - Static method in class alluxio.client.file.FileSystemUtils
Persists the given path to the under file system and returns once the persist is complete.
PersistCmdConfig - Class in alluxio.job.cmd.persist
A Cmd config for System Trigger job.
PersistCmdConfig(String, long, boolean, String) - Constructor for class alluxio.job.cmd.persist.PersistCmdConfig
Creates a new instance of PersistCmdConfig.
PersistCommandOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PersistCommandOptions
PersistCommandOptions - Class in alluxio.wire
Class to represent a persist options.
PersistCommandOptions(List<PersistFile>) - Constructor for class alluxio.wire.PersistCommandOptions
Creates a new instance of PersistCommandOptions.
PersistCommandOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PersistCommandOptions
PersistCommandOptionsOrBuilder - Interface in alluxio.grpc
 
PersistConfig - Class in alluxio.job.plan.persist
The configuration of persisting a file.
PersistConfig(String, long, boolean, String) - Constructor for class alluxio.job.plan.persist.PersistConfig
Creates a new instance of PersistConfig.
PersistDefinition - Class in alluxio.job.plan.persist
A job that persists a file into the under storage.
PersistDefinition() - Constructor for class alluxio.job.plan.persist.PersistDefinition
Constructs a new PersistDefinition.
PersistDirectory - Class in alluxio.master.backcompat.ops
Test for persisting a directory.
PersistDirectory() - Constructor for class alluxio.master.backcompat.ops.PersistDirectory
 
PERSISTED_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
PERSISTED_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
PERSISTED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PERSISTEDFILEFINGERPRINTS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemHeartbeatPOptions
 
PERSISTEDFILES_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemHeartbeatPRequest
 
PERSISTENCE_INVALID_JOB_ID - Static variable in class alluxio.Constants
 
PERSISTENCE_INVALID_UFS_PATH - Static variable in class alluxio.Constants
 
PERSISTENCE_STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PERSISTENCE_STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PERSISTENCE_STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
PERSISTENCE_STATE_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
PersistenceState - Enum in alluxio.master.file.meta
The persistence state of a file in the under-storage system.
PERSISTENCESTATE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
PERSISTENCEWAITTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
PERSISTENCEWAITTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
PersistFile - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PersistFile
PersistFile - Class in alluxio.master.backcompat.ops
Test for persisting a file.
PersistFile() - Constructor for class alluxio.master.backcompat.ops.PersistFile
 
PersistFile - Class in alluxio.wire
Class to represent a file persist info.
PersistFile(long, List<Long>) - Constructor for class alluxio.wire.PersistFile
Creates a new instance for persist file.
PersistFile.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.PersistFile
PersistFileOrBuilder - Interface in alluxio.grpc
 
PERSISTFILES_FIELD_NUMBER - Static variable in class alluxio.grpc.PersistCommandOptions
 
PersistJob - Class in alluxio.master.file
Represents a persist job.
PersistJob(long, long, AlluxioURI, String, ExponentialTimer) - Constructor for class alluxio.master.file.PersistJob
Creates a new instance of PersistJob.
PersistJob.CancelState - Enum in alluxio.master.file
Represents the possible cancel states.
PERSISTJOBID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PERSISTOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemCommandOptions
 
PersistRunner - Class in alluxio.master.job.tracker
A config runner for a Persist job.
PersistRunner(FileSystemContext, JobMaster) - Constructor for class alluxio.master.job.tracker.PersistRunner
constructor.
pickAWorker(String, Collection<WorkerInfo>) - Method in class alluxio.master.job.HashBasedWorkerAssignPolicy
 
pickAWorker(String, Collection<WorkerInfo>) - Method in class alluxio.master.job.RoundRobinWorkerAssignPolicy
 
pickAWorker(String, Collection<WorkerInfo>) - Method in class alluxio.master.job.WorkerAssignPolicy
Pick a worker based on the policy.
PIN_ON_CREATE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
pinBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Pins the block indicating subsequent access.
pingService(InetSocketAddress, ServiceType, AlluxioConfiguration, UserState) - Static method in class alluxio.util.network.NetworkAddressUtils
Test if the input address is serving an Alluxio service.
PINNED_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
PINNED_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
PINNED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
PINNEDFILEIDS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetPinnedFileIdsPResponse
 
PinnedInodeFileIds - Class in alluxio.master.file.meta
Keeps track of which files are pinned.
PinnedInodeFileIds() - Constructor for class alluxio.master.file.meta.PinnedInodeFileIds
 
PINNEDMEDIA_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
PlainSaslClientCallbackHandler - Class in alluxio.security.authentication.plain
A client side callback to put application provided username/password into SASL transport.
PlainSaslClientCallbackHandler(String, String) - Constructor for class alluxio.security.authentication.plain.PlainSaslClientCallbackHandler
Constructs a new client side callback.
PlainSaslServer - Class in alluxio.security.authentication.plain
This class provides PLAIN SASL authentication.
PlainSaslServer.Factory - Class in alluxio.security.authentication.plain
This class is used to create an instances of PlainSaslServer.
PlainSaslServerCallbackHandler - Class in alluxio.security.authentication.plain
A callback that is used by the SASL mechanisms to get further information to complete the authentication.
PlainSaslServerCallbackHandler(AuthenticationProvider, ImpersonationAuthenticator) - Constructor for class alluxio.security.authentication.plain.PlainSaslServerCallbackHandler
Constructs a new callback handler.
PlainSaslServerProvider - Class in alluxio.security.authentication.plain
The Java SunSASL provider supports CRAM-MD5, DIGEST-MD5 and GSSAPI mechanisms on the server side.
PlainSaslServerProvider() - Constructor for class alluxio.security.authentication.plain.PlainSaslServerProvider
Constructs a new provider for the SASL server when using the PLAIN mechanism.
PLAN_VALUE - Static variable in enum alluxio.grpc.JobType
PLAN = 1;
PlanConfig - Interface in alluxio.job.plan
A plan configuration.
PlanCoordinator - Class in alluxio.master.job.plan
A job coordinator that coordinates the distributed task execution on the worker nodes.
PlanDefinition<T extends JobConfig,P extends Serializable,R extends Serializable> - Interface in alluxio.job.plan
A job definition.
PlanDefinitionRegistry - Enum in alluxio.job.plan
The central registry of all the job definitions.
PlanInfo - Class in alluxio.job.plan.meta
The job information used by the job master internally.
PlanInfo(long, JobConfig, Consumer<PlanInfo>) - Constructor for class alluxio.job.plan.meta.PlanInfo
Creates a new instance of PlanInfo.
PlanInfo - Class in alluxio.job.wire
The plan description.
PlanInfo(long, String, Status, long, String) - Constructor for class alluxio.job.wire.PlanInfo
JobInfo constructor exposed for testing.
PlanInfo(PlanInfo, boolean) - Constructor for class alluxio.job.wire.PlanInfo
Constructs the plan info from the job master's internal representation of job info.
PlanInfo(JobInfo) - Constructor for class alluxio.job.wire.PlanInfo
Constructs a new instance of PlanInfo from a proto object.
PlanTracker - Class in alluxio.master.job.plan
The PlanTracker is used to create, remove, and provide access to the set of currently scheduled or finished jobs.
PlanTracker(long, long, long, WorkflowTracker) - Constructor for class alluxio.master.job.plan.PlanTracker
Create a new instance of PlanTracker.
PMode - Class in alluxio.grpc
Protobuf type alluxio.grpc.PMode
PMode.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.PMode
PModeOrBuilder - Interface in alluxio.grpc
 
Point(IOTaskResult.IOMode, double, long) - Constructor for class alluxio.stress.worker.IOTaskResult.Point
 
Policy - Class in alluxio.proto.journal
 
Policy.PolicyDefinitionEntry - Class in alluxio.proto.journal
next available id: 5
Policy.PolicyDefinitionEntry.Builder - Class in alluxio.proto.journal
next available id: 5
Policy.PolicyDefinitionEntryOrBuilder - Interface in alluxio.proto.journal
 
Policy.PolicyRemoveEntry - Class in alluxio.proto.journal
next available id: 2
Policy.PolicyRemoveEntry.Builder - Class in alluxio.proto.journal
next available id: 2
Policy.PolicyRemoveEntryOrBuilder - Interface in alluxio.proto.journal
 
POLICY_DEFINITION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
POLICY_ENGINE_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
POLICY_ENGINE_NAME - Static variable in class alluxio.Constants
 
POLICY_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPResponse
 
POLICY_FIELD_NUMBER - Static variable in class alluxio.grpc.ListPolicyPResponse
 
POLICY_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
POLICY_MASTER_CLIENT_SERVICE = 1002;
POLICY_REMOVE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
POLICY_VALUE - Static variable in enum alluxio.grpc.JobSource
POLICY = 2;
PolicyConfig - Class in alluxio.job.cmd.replicate
A Cmd config for Policy.
PolicyConfig() - Constructor for class alluxio.job.cmd.replicate.PolicyConfig
 
PolicyInfo - Class in alluxio.grpc
next available id: 5
PolicyInfo.Builder - Class in alluxio.grpc
next available id: 5
PolicyInfoOrBuilder - Interface in alluxio.grpc
 
PolicyMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains policy master service endpoints for Alluxio clients.
PolicyMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains policy master service endpoints for Alluxio clients.
PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service PolicyMasterClientService.
PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service PolicyMasterClientService.
PolicyMasterClientServiceGrpc.PolicyMasterClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service PolicyMasterClientService.
PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service PolicyMasterClientService.
PolicyMasterClientServiceImplBase() - Constructor for class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceImplBase
 
PolicyMasterProto - Class in alluxio.grpc
 
POLICYNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPRequest
 
POLICYNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.GetActionInfoRequest
 
POLICYNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.GetPolicyStatusPRequest
 
POLICYNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.RemovePolicyPRequest
 
POLICYNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.TriggerPolicyRequest
 
PolicyStatus - Class in alluxio.grpc
next available id: 12
PolicyStatus.Builder - Class in alluxio.grpc
next available id: 12
PolicyStatusOrBuilder - Interface in alluxio.grpc
 
poll() - Method in class alluxio.master.scheduler.Scheduler.BoundedPriorityBlockingQueue
 
poll() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
poll(long, TimeUnit) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
pollAllPendingCommands(long) - Method in class alluxio.master.job.command.CommandManager
Polls all the pending commands to a worker and removes the commands from the queue.
pollBuffer(TMesg) - Method in interface alluxio.grpc.BufferRepository
Retrieves and removes a buffer from the store.
pollBuffer(T) - Method in class alluxio.grpc.DataMessageMarshaller
 
pollExpiredBuckets(long) - Method in class alluxio.master.file.meta.TtlBucketList
Polls buckets whose ttl interval has expired before the specified time, that is, the bucket's interval start time should be less than or equal to (specified time - ttl interval).
pollFilesToPersist(long) - Method in interface alluxio.master.file.async.AsyncPersistHandler
Polls the files for persistence on the given worker.
pollFilesToPersist(long) - Method in class alluxio.master.file.async.DefaultAsyncPersistHandler
Polls the files to send to the given worker for persistence.
PollingMasterInquireClient - Class in alluxio.master
PollingMasterInquireClient finds the address of the primary master by polling a list of master addresses to see if their RPC servers are serving.
PollingMasterInquireClient(List<InetSocketAddress>, AlluxioConfiguration, UserState, ServiceType) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient(List<InetSocketAddress>, Supplier<RetryPolicy>, AlluxioConfiguration, ServiceType) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient(List<InetSocketAddress>, Supplier<RetryPolicy>, AlluxioConfiguration, UserState, ServiceType) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient.MultiMasterConnectDetails - Class in alluxio.master
Details used to connect to the leader Alluxio master when there are multiple potential leaders.
pollNextLocalTask() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if the current thread is operating in a ForkJoinPool.
pollSubmission() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Removes and returns the next unexecuted submission if one is available.
pollSubmission() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
If the current thread is operating in a ForkJoinPool, unschedules and returns, without executing, a task externally submitted to the pool, if one is available.
pollTask() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
If the current thread is operating in a ForkJoinPool, unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if one is available, or if not available, a task that was forked by some other thread, if available.
Pool<T> - Interface in alluxio.resource
Interface representing a pool of resources to be temporarily used and returned.
PooledDirectNioByteBuf - Class in alluxio.network.protocol.databuffer
Pooled direct NIO byte buffer allocated from NioDirectBufferPool wrapped in Netty ByteBuf.
PooledResource<T> - Class in alluxio.resource
A pooled resource that was acquired from a Pool, and will be released back to the pool when it's closed.
PooledResource(T, Pool<T>) - Constructor for class alluxio.resource.PooledResource
Creates a new pooled resource with the pool from which it was acquired.
pop() - Method in class alluxio.util.executor.ControllableQueue
 
populateContentTypeInXAttr(Map<String, ByteString>, String) - Static method in class alluxio.proxy.s3.S3RestUtils
Populate xattr with content type info from header.
populateCounterValues(Map<String, Metric>, Map<String, Counter>, HttpServletRequest) - Method in class alluxio.web.WebInterfaceAbstractMetricsServlet
Populates operation metrics for displaying in the UI.
populateTaggingInXAttr(Map<String, ByteString>, String, S3AuditContext, String) - Static method in class alluxio.proxy.s3.S3RestUtils
Populate xattr map with tagging info from tagging header.
PortAvailabilityValidationTask - Class in alluxio.cli
Task for validating whether a specific port is available.
PortAvailabilityValidationTask(NetworkAddressUtils.ServiceType, String, AlluxioConfiguration) - Constructor for class alluxio.cli.PortAvailabilityValidationTask
Creates a new instance of PortAvailabilityValidationTask.
PortCoordination - Class in alluxio.multi.process
Class for coordinating between test suites so that they don't conflict in ports.
PortCoordination() - Constructor for class alluxio.multi.process.PortCoordination
 
PortCoordination.ReservedPort - Class in alluxio.multi.process
A port that has been reserved for the purposes of a single test.
PORTS_PER_MASTER - Static variable in class alluxio.multi.process.MultiProcessCluster
 
PORTS_PER_WORKER - Static variable in class alluxio.multi.process.MultiProcessCluster
 
pos() - Method in class alluxio.client.block.stream.BlockWorkerDataReader
 
pos() - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
 
pos() - Method in interface alluxio.client.block.stream.DataReader
 
pos() - Method in interface alluxio.client.block.stream.DataWriter
 
pos() - Method in class alluxio.client.block.stream.GrpcDataReader
 
pos() - Method in class alluxio.client.block.stream.GrpcDataWriter
 
pos() - Method in class alluxio.client.block.stream.NettyDataReader
 
pos() - Method in class alluxio.client.block.stream.NettyDataWriter
 
pos() - Method in class alluxio.client.block.stream.SharedGrpcDataReader
 
pos() - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
POSITION_SHORT_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
POSITION_SHORT_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsReadOptions
 
Positioned - Interface in alluxio
An interface for an object which tracks and can report its current position (for example a stream).
positionedRead(long, byte[], int, int) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
positionedRead(long, byte[], int, int) - Method in class alluxio.client.file.PositionReadFileInStream
 
positionedRead(long, byte[], int, int) - Method in class alluxio.client.file.ufs.UfsFileInStream
 
positionedRead(long, byte[], int, int) - Method in interface alluxio.client.PositionedReadable
Reads up to the specified number of bytes, from a given position within a file, and return the number of bytes read.
positionedRead(long, byte[], int, int) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
PositionedReadable - Interface in alluxio.client
Stream that permits positional reading.
PositionReader - Interface in alluxio
Position read interface.
PositionReaderTest - Class in alluxio
A position reader test to test position read from the given reader.
PositionReaderTest(PositionReader, int) - Constructor for class alluxio.PositionReaderTest
 
PositionReadFileInStream - Class in alluxio.client.file
Implementation of FileInStream that reads from a dora cache if possible.
PositionReadFileInStream(PositionReader, long) - Constructor for class alluxio.client.file.PositionReadFileInStream
Constructor.
post(String, String, Integer, HttpUtils.IProcessInputStream) - Static method in class alluxio.util.network.HttpUtils
Uses the post method to send a url with arguments by http, this method can call RESTful Api.
post(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the post method to send a url with arguments by http, this method can call RESTful Api.
postBucket(String, String, int, InputStream) - Method in class alluxio.proxy.s3.S3RestServiceHandler
Currently implements the DeleteObjects request type if the query parameter "delete" exists.
postProcess(ResponseEventContext) - Method in class alluxio.client.file.dora.netty.event.CancelledResponseEvent
 
postProcess(ResponseEventContext) - Method in class alluxio.client.file.dora.netty.event.ChannelErrorResponseEvent
 
postProcess(ResponseEventContext) - Method in class alluxio.client.file.dora.netty.event.DataResponseEvent
 
postProcess(ResponseEventContext) - Method in class alluxio.client.file.dora.netty.event.EofResponseEvent
 
postProcess(ResponseEventContext) - Method in interface alluxio.client.file.dora.netty.event.ResponseEvent
Do some post-processing logic for the response event.
postProcess(ResponseEventContext) - Method in class alluxio.client.file.dora.netty.event.ServerErrorResponseEvent
 
postProcess(ResponseEventContext) - Method in class alluxio.client.file.dora.netty.event.UfsReadHeartBeatResponseEvent
 
postProcessing(long) - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Do post-processing on the command information, including printing file paths and statistics.
PRECONDITION_FAILED - Static variable in class alluxio.s3.S3ErrorCode.Name
 
PRECONDITION_FAILED - Static variable in class alluxio.s3.S3ErrorCode
 
PreconditionMessage - Enum in alluxio.exception
Precondition messages used across Alluxio.
prefetchChildren(AlluxioURI, MountTable) - Method in class alluxio.underfs.UfsStatusCache
Submit a request to asynchronously fetch the statuses corresponding to a given directory.
PREFIX_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
 
PrefixList - Class in alluxio.collections
Prefix list is used to do file filtering.
PrefixList(List<String>) - Constructor for class alluxio.collections.PrefixList
Prefix list is used to do file filtering.
PrefixList(String, String) - Constructor for class alluxio.collections.PrefixList
Prefix list is used to do file filtering.
prepare() - Method in class alluxio.stress.cli.Benchmark
Prepares to run the test.
prepare() - Method in class alluxio.stress.cli.client.StressClientIOBench
 
prepare() - Method in class alluxio.stress.cli.UfsIOBench
 
prepare() - Method in class alluxio.stress.cli.worker.StressWorkerBench
 
prepareForCreateTempFile(URIStatus) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
Prepare CreateFilePOptions for create temp multipart upload file.
prepareForCreateTempFile(URIStatus) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
Prepare CreateFilePOptions for create temp multipart upload file.
PREVIOUS_VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
PRIMARY_VALUE - Static variable in enum alluxio.grpc.NodeState
PRIMARY = 1;
primaryMaster() - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
Creates a MasterSelectionPolicy that selects the primary master to connect.
PrimarySelector - Interface in alluxio.master
Interface for a class which can determine whether the local master is the primary.
PrimarySelector.Factory - Class in alluxio.master
Factory for creating primary selectors.
PrincipalType - Enum in alluxio.grpc.table
Protobuf enum alluxio.grpc.table.PrincipalType
print(PrintStream) - Method in class alluxio.job.util.TimeSeries
Print the time series densely, i.e.
printCollection(String, Collection<? extends Object>) - Method in class alluxio.proxy.s3.S3Handler
Utility function to dump a collection into a string.
printCommandInfo(Command, PrintWriter) - Static method in class alluxio.cli.fs.command.HelpCommand
Prints the info about a command to the given print writer.
printFailed() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Log failed file information.
printHelp(String) - Static method in class alluxio.cli.bundler.CollectInfo
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.DocGenerator
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.GetConf
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.LogLevel
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.ValidateEnv
Prints the help message.
printHelp(String) - Static method in class alluxio.cli.ValidateHdfsMount
Print help with the message.
printJobsStatus() - Method in class alluxio.master.scheduler.Scheduler
Print job status.
printMap(String, Map<? extends Object, ? extends Object>) - Method in class alluxio.proxy.s3.S3Handler
Utility function to dump a map into a string.
printTestStatus(boolean, PrintStream) - Static method in class alluxio.cli.RunTestUtils
Prints information of the test result to redirected streams.
printTestStatus(boolean) - Static method in class alluxio.cli.RunTestUtils
Prints information of the test result.
printThreadInfo(PrintStream, String) - Static method in class alluxio.util.ThreadUtils
Prints the information and stack traces of all threads.
printUsage() - Method in class alluxio.cli.AbstractShell
Prints usage for all commands.
printUsage(Options) - Static method in class alluxio.cli.Version
Prints the usage of the version command.
PRIORITY_FIELD_NUMBER - Static variable in class alluxio.grpc.QuorumServerInfo
 
PRIVILEGE_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
PRIVILEGE_MASTER_CLIENT_SERVICE = 1001;
process(Collection<Long>) - Method in interface alluxio.master.file.BlockDeletionContext.BlockDeletionListener
Processes block deletion.
Process - Interface in alluxio
Interface representing an Alluxio process.
process(InputStream) - Method in interface alluxio.util.network.HttpUtils.IProcessInputStream
 
PROCESS_POOL_DIRECT_MEM_USED - Static variable in class alluxio.metrics.MetricKey
 
PROCESS_TYPE - Static variable in class alluxio.util.CommonUtils
Represents the type of Alluxio process running in this JVM.
processAsync(AlluxioURI, List<Inode>) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
processAsync(AlluxioURI, List<Inode>) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
processAsync(AlluxioURI, List<Inode>) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Processes the given path for the cache.
ProcessCheckRunnable(String) - Constructor for class alluxio.master.MasterHealthCheckClient.ProcessCheckRunnable
Creates a new instance of ProcessCheckRunnable.
processExisting(AlluxioURI) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
processExisting(AlluxioURI) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
processExisting(AlluxioURI) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Processes the given path that already exists.
processFailures(String, Set<String>, String) - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
processHeader(CommandLine) - Method in class alluxio.cli.fs.command.AbstractFileSystemCommand
Processes the header of the command.
processHttpResponse(HttpResponse) - Method in class alluxio.worker.s3.S3NettyHandler
Writes HttpResponse into context channel, After writes context channel will close.
processHttpResponse(HttpResponse, boolean) - Method in class alluxio.worker.s3.S3NettyHandler
Writes HttpResponse into context channel.
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.block.DefaultBlockMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.file.meta.MountTable.State
 
processJournalEntry(Journal.JournalEntry) - Method in interface alluxio.master.journal.DelegatingJournaled
 
processJournalEntry(Journal.JournalEntry) - Method in interface alluxio.master.journal.Journaled
Attempts to apply a journal entry.
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.journal.JournaledGroup
 
processJournalEntry(Journal.JournalEntry) - Method in interface alluxio.master.journal.NoopJournaled
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.journal.raft.BufferedJournalApplier
Processes given journal entry for applying.
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.journal.SingleEntryJournaled
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.meta.DefaultMetaMaster
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.meta.DefaultMetaMaster.State
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.meta.PathProperties.State
 
processJournalEntry(Journal.JournalEntry) - Method in class alluxio.master.scheduler.JournaledJobMetaStore
 
processMappedResponse(BlockReader, long) - Method in class alluxio.worker.s3.S3NettyHandler
Writes data into netty channel by copying through ByteBuf.
processMethodProfiles(long, long, Function<Benchmark.ProfileInput, String>) - Method in class alluxio.stress.cli.Benchmark
 
PROCESSOR_BIT - Static variable in class alluxio.util.OSUtils
The processor bit.
processResponse(CopyJob.CopyTask) - Method in class alluxio.master.job.CopyJob
 
processResponse(DoraLoadJob.DoraLoadTask) - Method in class alluxio.master.job.DoraLoadJob
 
processResponse(LoadJob.LoadTask) - Method in class alluxio.master.job.LoadJob
 
processResponse(MoveJob.MoveTask) - Method in class alluxio.master.job.MoveJob
 
processResponse(HttpServletResponse, Response) - Static method in class alluxio.proxy.s3.S3Handler
Process the response returned from S3Task core logic to write to downstream.
processResponse(T) - Method in interface alluxio.scheduler.job.Job
process task result.
processTransferResponse(DataBuffer) - Method in class alluxio.worker.s3.S3NettyHandler
Writes a DataBuffer into netty channel.
ProcessUtils - Class in alluxio
Utility methods for Alluxio Processes.
PROFILE_AGENT - Static variable in class alluxio.stress.BaseParameters
 
PROGRESSPERCENTAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
PROGRESSREPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobProgressPResponse
 
ProjectConstants - Class in alluxio
Project constants from compilation time by maven.
PrometheusMetricsServlet - Class in alluxio.metrics.sink
A sink that exposes metrics data in prometheus format by HTTP.
PrometheusMetricsServlet(MetricRegistry) - Constructor for class alluxio.metrics.sink.PrometheusMetricsServlet
Creates a new PrometheusMetricsServlet with a MetricRegistry.
PrometheusMetricsServlet(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.PrometheusMetricsServlet
Creates a new PrometheusMetricsServlet with a MetricRegistry.
promote() - Method in class alluxio.master.service.jvmmonitor.JvmMonitorService
 
promote() - Method in class alluxio.master.service.NoopService
 
promote() - Method in class alluxio.master.service.rpc.RpcServerService
 
promote() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
promote() - Method in interface alluxio.master.service.SimpleService
Promotes the service to NodeState.PRIMARY state.
PROMOTE_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
PROMOTE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
PROMOTE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
propagateCompletion() - Method in class alluxio.concurrent.jsr.CountedCompleter
Equivalent to CountedCompleter.tryComplete() but does not invoke CountedCompleter.onCompletion(CountedCompleter) along the completion path: If the pending count is nonzero, decrements the count; otherwise, similarly tries to complete this task's completer, if one exists, else marks this task as complete.
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigProperties
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.grpc.InconsistentProperties
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPOptions
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.grpc.SetPathConfigurationPRequest
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsInfo
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateConfigurationPRequest
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
Property - Class in alluxio.wire
Wire representation of a configuration property.
Property(String, Object, Source) - Constructor for class alluxio.wire.Property
Creates a new property.
PropertyCreators() - Constructor for class alluxio.conf.PropertyKey.PropertyCreators
 
PropertyKey - Class in alluxio.conf
Configuration property keys.
PropertyKey.Builder - Class in alluxio.conf
Builder to create PropertyKey instances.
PropertyKey.ConsistencyCheckLevel - Enum in alluxio.conf
The consistency check level to apply to a certain property key.
PropertyKey.DisplayType - Enum in alluxio.conf
Indicates how the property value should be displayed.
PropertyKey.Name - Class in alluxio.conf
A nested class to hold named string constants for their corresponding properties.
PropertyKey.PropertyCreators - Class in alluxio.conf
puts property creators in a nested class to avoid NPE in enum static initialization.
PropertyKey.PropertyType - Enum in alluxio.conf
Indicates property type.
PropertyKey.Template - Enum in alluxio.conf
A set of templates to generate the names of parameterized properties given different parameters.
ProtoBufJournalFormatter - Class in alluxio.master.journalv0
Reads and writes protocol buffer journal entries.
ProtoBufJournalFormatter() - Constructor for class alluxio.master.journalv0.ProtoBufJournalFormatter
Constructs a new ProtoBufJournalFormatter.
ProtobufUtils - Class in alluxio.master
Utility methods for conversion between wire types and protobuf types.
Protocol - Class in alluxio.proto.dataserver
 
Protocol.AsyncCacheRequest - Class in alluxio.proto.dataserver
Options for caching a block asynchronously next available id: 6
Protocol.AsyncCacheRequest.Builder - Class in alluxio.proto.dataserver
Options for caching a block asynchronously next available id: 6
Protocol.AsyncCacheRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.CreateUfsFileOptions - Class in alluxio.proto.dataserver
Options to create a UFS file.
Protocol.CreateUfsFileOptions.Builder - Class in alluxio.proto.dataserver
Options to create a UFS file.
Protocol.CreateUfsFileOptionsOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.Heartbeat - Class in alluxio.proto.dataserver
A heartbeat
Protocol.Heartbeat.Builder - Class in alluxio.proto.dataserver
A heartbeat
Protocol.HeartbeatOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCloseRequest - Class in alluxio.proto.dataserver
next available id: 2
Protocol.LocalBlockCloseRequest.Builder - Class in alluxio.proto.dataserver
next available id: 2
Protocol.LocalBlockCloseRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCompleteRequest - Class in alluxio.proto.dataserver
next available id: 3
Protocol.LocalBlockCompleteRequest.Builder - Class in alluxio.proto.dataserver
next available id: 3
Protocol.LocalBlockCompleteRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCreateRequest - Class in alluxio.proto.dataserver
next available id: 6
Protocol.LocalBlockCreateRequest.Builder - Class in alluxio.proto.dataserver
next available id: 6
Protocol.LocalBlockCreateRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockCreateResponse - Class in alluxio.proto.dataserver
next available id: 2
Protocol.LocalBlockCreateResponse.Builder - Class in alluxio.proto.dataserver
next available id: 2
Protocol.LocalBlockCreateResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockOpenRequest - Class in alluxio.proto.dataserver
next available id: 3
Protocol.LocalBlockOpenRequest.Builder - Class in alluxio.proto.dataserver
next available id: 3
Protocol.LocalBlockOpenRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.LocalBlockOpenResponse - Class in alluxio.proto.dataserver
next available id: 2
Protocol.LocalBlockOpenResponse.Builder - Class in alluxio.proto.dataserver
next available id: 2
Protocol.LocalBlockOpenResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.OpenUfsBlockOptions - Class in alluxio.proto.dataserver
Options to open a UFS block.
Protocol.OpenUfsBlockOptions.Builder - Class in alluxio.proto.dataserver
Options to open a UFS block.
Protocol.OpenUfsBlockOptionsOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.ReadRequest - Class in alluxio.proto.dataserver
The read request.
Protocol.ReadRequest.Builder - Class in alluxio.proto.dataserver
The read request.
Protocol.ReadRequestOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.ReadResponse - Class in alluxio.proto.dataserver
The read response.
Protocol.ReadResponse.Builder - Class in alluxio.proto.dataserver
The read response.
Protocol.ReadResponse.Type - Enum in alluxio.proto.dataserver
Protobuf enum alluxio.proto.dataserver.ReadResponse.Type
Protocol.ReadResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.RequestType - Enum in alluxio.proto.dataserver
The read/write request type.
Protocol.Response - Class in alluxio.proto.dataserver
The response.
Protocol.Response.Builder - Class in alluxio.proto.dataserver
The response.
Protocol.ResponseOrBuilder - Interface in alluxio.proto.dataserver
 
Protocol.WriteRequest - Class in alluxio.proto.dataserver
The write request.
Protocol.WriteRequest.Builder - Class in alluxio.proto.dataserver
The write request.
Protocol.WriteRequestOrBuilder - Interface in alluxio.proto.dataserver
 
ProtoMessage - Class in alluxio.util.proto
A simple wrapper around the MessageLite class in Protobuf for a few messages defined and generated in Alluxio.
ProtoMessage(Protocol.ReadRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.WriteRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.Response) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.ReadResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockOpenRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockOpenResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCloseRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCreateRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCreateResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCompleteRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.AsyncCacheRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.Heartbeat) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoParsingException - Exception in alluxio.wire
Thrown when parsing fails.
ProtoParsingException(Throwable) - Constructor for exception alluxio.wire.ProtoParsingException
 
ProtoParsingException(String) - Constructor for exception alluxio.wire.ProtoParsingException
Constructs a new exception with detailed message.
ProtoParsingException(String, Throwable) - Constructor for exception alluxio.wire.ProtoParsingException
Constructs a new exception with detailed message and cause.
protoToCmdStatusBlock(CmdStatusBlock) - Static method in class alluxio.job.ProtoUtils
Convert proto to list of SimpleJobStatusBlock.
protoToShort(PMode) - Static method in class alluxio.util.ModeUtils
Used to get short value of a proto PMode.
ProtoUtils - Class in alluxio.job
Utility for converting proto job representation to java job representation.
ProtoUtils - Class in alluxio.table
Protobuf related utils.
ProtoUtils() - Constructor for class alluxio.table.ProtoUtils
 
ProtoUtils - Class in alluxio.util.proto
Protobuf related utils.
provideGrpcBindAddress() - Method in class alluxio.worker.modules.GrpcServerModule
 
provideNettyBindAddress() - Method in class alluxio.worker.modules.NettyServerModule
 
provideS3BindAddress() - Method in class alluxio.worker.modules.NettyServerModule
 
PROXY_AUDIT_LOG_ENTRIES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
PROXY_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_CHECK_UPLOADID_STATUS_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_CLEANUP_MULTIPART_UPLOAD_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_CLEANUP_TEMP_MULTIPART_UPLOAD_OBJ_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_COMPLETE_MP_UPLOAD_MERGE_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_MASTER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_MASTER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
PROXY_META_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
PROXY_S3_BUCKET_NAMING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_BUCKET_NAMING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_BUCKETPATHCACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_BUCKETPATHCACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_TIME_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_TIME_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_MIN_PART_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_MIN_PART_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_DELETE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_DELETE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_GLOBAL_READ_RATE_LIMIT_MB - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_GLOBAL_READ_RATE_LIMIT_MB - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_HEADER_METADATA_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_METADATA_HEADER_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_DELAY - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_DELAY - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_SINGLE_CONNECTION_READ_RATE_LIMIT_MB - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_SINGLE_CONNECTION_READ_RATE_LIMIT_MB - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_TAGGING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_TAGGING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_ASYNC_HEAVY_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_ASYNC_HEAVY_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_ASYNC_HEAVY_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_ASYNC_HEAVY_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_ASYNC_HEAVY_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_ASYNC_HEAVY_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_ASYNC_LIGHT_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_ASYNC_LIGHT_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_ASYNC_LIGHT_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_ASYNC_LIGHT_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_ASYNC_LIGHT_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_ASYNC_LIGHT_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_ASYNC_PROCESSING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_ASYNC_PROCESSING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_V2_HEAVY_POOL - Static variable in class alluxio.proxy.s3.S3RequestServlet
 
PROXY_S3_V2_LIGHT_POOL - Static variable in class alluxio.proxy.s3.S3RequestServlet
 
PROXY_S3_V2_VERSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_V2_VERSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_WRITE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_WRITE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_STREAM_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_STREAM_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
PROXY_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
PROXY_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
PROXY_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
PROXYADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyHeartbeatPOptions
 
ProxyCommand - Class in alluxio.cli.fsadmin.report
Prints information about proxy instances in the cluster.
ProxyCommand(MetaMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.ProxyCommand
Creates a new instance of ProxyCommand.
ProxyHealthCheckClient - Class in alluxio.proxy
ProxyHealthCheckClient check if the proxy server is serving requests.
ProxyHealthCheckClient(InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.proxy.ProxyHealthCheckClient
Creates a proxy health check client.
proxyHeartbeat(ProxyHeartbeatPRequest, StreamObserver<ProxyHeartbeatPResponse>) - Method in interface alluxio.grpc.MetaMasterProxyServiceGrpc.AsyncService
Stateless heartbeat from proxy instances to report the current status.
proxyHeartbeat(ProxyHeartbeatPRequest) - Method in class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceBlockingStub
Stateless heartbeat from proxy instances to report the current status.
proxyHeartbeat(ProxyHeartbeatPRequest) - Method in class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceFutureStub
Stateless heartbeat from proxy instances to report the current status.
proxyHeartbeat(ProxyHeartbeatPRequest, StreamObserver<ProxyHeartbeatPResponse>) - Method in class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceStub
Stateless heartbeat from proxy instances to report the current status.
proxyHeartbeat(ProxyHeartbeatPRequest) - Method in class alluxio.master.meta.DefaultMetaMaster
 
proxyHeartbeat(ProxyHeartbeatPRequest) - Method in interface alluxio.master.meta.MetaMaster
A Proxy periodically heartbeats with the primary master.
proxyHeartbeat(ProxyHeartbeatPRequest, StreamObserver<ProxyHeartbeatPResponse>) - Method in class alluxio.master.meta.MetaMasterProxyServiceHandler
 
proxyHeartbeat() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
Sends a heartbeat to the primary master.
ProxyHeartbeatPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyHeartbeatPOptions
ProxyHeartbeatPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyHeartbeatPOptions
ProxyHeartbeatPOptionsOrBuilder - Interface in alluxio.grpc
 
ProxyHeartbeatPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyHeartbeatPRequest
ProxyHeartbeatPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyHeartbeatPRequest
ProxyHeartbeatPRequestOrBuilder - Interface in alluxio.grpc
 
ProxyHeartbeatPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyHeartbeatPResponse
ProxyHeartbeatPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyHeartbeatPResponse
ProxyHeartbeatPResponseOrBuilder - Interface in alluxio.grpc
 
ProxyInfo - Class in alluxio.master.meta
Proxy information.
ProxyInfo(NetAddress) - Constructor for class alluxio.master.meta.ProxyInfo
Creates a new instance of ProxyInfo.
ProxyMasterSync - Class in alluxio.proxy
The Proxy will maintain a stateless heartbeat with the primary master.
ProxyMasterSync(Address, MasterClientContext, long) - Constructor for class alluxio.proxy.ProxyMasterSync
Creates a new instance of ProxyMasterSync.
ProxyProcess - Interface in alluxio.proxy
A proxy in the Alluxio system.
ProxyProcess.Factory - Class in alluxio.proxy
Factory for creating ProxyProcess.
ProxyStatus - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyStatus
ProxyStatus.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.ProxyStatus
PROXYSTATUSES_FIELD_NUMBER - Static variable in class alluxio.grpc.ListProxyStatusPResponse
 
ProxyStatusOrBuilder - Interface in alluxio.grpc
 
ProxyWebServer - Class in alluxio.web
The Alluxio proxy web server.
ProxyWebServer(String, InetSocketAddress, ProxyProcess) - Constructor for class alluxio.web.ProxyWebServer
Creates a new instance of ProxyWebServer.
PublicApi - Annotation Type in alluxio.annotation
A public API annotation for annotating classes and interfaces that are externally facing.
pushWriteLockedEdge(Inode, String) - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
pushWriteLockedEdge(Inode, String) - Method in interface alluxio.master.file.meta.InodeLockList
Leapfrogs the final edge write lock forward, reducing the lock list's write-locked scope.
pushWriteLockedEdge(Inode, String) - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
put(PageId, byte[]) - Method in interface alluxio.client.file.cache.CacheManager
Puts a page into the cache manager.
put(PageId, ByteBuffer) - Method in interface alluxio.client.file.cache.CacheManager
Puts a page into the cache manager.
put(PageId, byte[], CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
Puts a page into the cache manager with scope and quota respected.
put(PageId, ByteBuffer, CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
Puts a page into the cache manager with scope and quota respected.
put(PageId, ByteBuffer, CacheContext) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
put(PageId, int, CacheScope) - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
put(T, int, CacheScope) - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
Insert an item into cuckoo filter.
put(T, int, CacheScope) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
put(PageId, ByteBuffer, CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
 
put(PageId, int, CacheScope) - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
put(PageId, byte[]) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
put(PageId, ByteBuffer, CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
put(PageId, byte[]) - Method in interface alluxio.client.file.cache.PageStore
Writes a new page from a source channel to the store.
put(PageId, byte[], boolean) - Method in interface alluxio.client.file.cache.PageStore
Writes a new page from a source channel to the store.
put(PageId, ByteBuffer, boolean) - Method in interface alluxio.client.file.cache.PageStore
Writes a new page from a source channel to the store.
put(PageId, int, CacheScope) - Method in interface alluxio.client.file.cache.ShadowCacheManager
Puts a page with specified size and scope into the shadow cache manager.
put(PageId, ByteBuffer, boolean) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
put(PageId, ByteBuffer, boolean) - Method in class alluxio.client.file.cache.store.MemoryPageStore
 
put(PageId, ByteBuffer, boolean) - Method in class alluxio.client.file.cache.TimeBoundPageStore
 
put(AlluxioURI, URIStatus) - Method in class alluxio.client.file.MetadataCache
 
put(String, URIStatus) - Method in class alluxio.client.file.MetadataCache
 
put(AlluxioURI, List<URIStatus>) - Method in class alluxio.client.file.MetadataCache
Caches list status results of a directory.
put(K, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
put(PropertyKey, Object, Source) - Method in class alluxio.conf.AlluxioProperties
Puts the key value pair specified by users.
put(K, V) - Method in class alluxio.master.metastore.caching.Cache
Writes a key/value pair to the cache.
put(FileInStream) - Method in class alluxio.StreamCache
 
put(FileOutStream) - Method in class alluxio.StreamCache
 
put(T) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
put(String, DoraMeta.FileStatus) - Method in class alluxio.worker.dora.DoraMetaManager
Puts meta of a file into the metastore, and invalidates the file data cache.
putAddedBlocksOnTiers(String, TierList) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
putAll(Map<? extends K, ? extends V>) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
putAllAddedBlocksOnTiers(Map<String, TierList>) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
putAllCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
map<string, int64> capacityBytesOnTiers = 2;
putAllCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> capacityBytesOnTiers = 2;
putAllCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> capacityBytesOnTiers = 8;
putAllColumn(Map<String, ColumnStatisticsInfo>) - Method in class alluxio.grpc.table.FileStatistics.Builder
map column names to column statistics
putAllColumnConstraints(Map<String, Domain>) - Method in class alluxio.grpc.table.Constraint.Builder
maps column to constraint, columns not present are not constrained
putAllCurrentBlocksOnTiers(Map<String, TierList>) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
putAllErrors(Map<String, InconsistentProperties>) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
putAllErrors(Map<String, String>) - Method in class alluxio.grpc.PolicyStatus.Builder
map<string, string> errors = 10;
putAllLostStorage(Map<String, StorageList>) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of lost storage paths on all tiers
putAllLostStorage(Map<String, StorageList>) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of tier alias to a list of lost storage paths.
putAllLostStorage(Map<String, StorageList>) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
a map from tier alias to the lost storage paths
putAllMetrics(Map<String, MetricValue>) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
putAllMountPoints(Map<String, MountPointInfo>) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
putAllOptions(Map<String, String>) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
putAllParameter(Map<String, String>) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
putAllParameters(Map<String, String>) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
map<string, string> parameters = 7;
putAllParameters(Map<String, String>) - Method in class alluxio.grpc.table.TableInfo.Builder
map<string, string> parameters = 7;
putAllPartitionStatistics(Map<String, ColumnStatisticsList>) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
putAllPathConfigs(Map<String, ConfigProperties>) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
putAllProperties(Map<String, String>) - Method in class alluxio.grpc.MountPointInfo.Builder
map<string, string> properties = 6;
putAllProperties(Map<String, String>) - Method in class alluxio.grpc.MountPOptions.Builder
map<string, string> properties = 2;
putAllProperties(Map<String, String>) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
map<string, string> properties = 2;
putAllProperties(Map<String, String>) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
map<string, string> properties = 1;
putAllProperties(Map<String, String>) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
map<string, string> properties = 2;
putAllSerdelibParameters(Map<String, String>) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
map<string, string> serdelib_parameters = 4;
putAllSerdeParameters(Map<String, String>) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
map<string, string> serde_parameters = 5;
putAllStats(Map<String, ColumnStatisticsInfo>) - Method in class alluxio.grpc.table.Layout.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
putAllStatus(Map<String, Boolean>) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
map<string, bool> status = 1;
putAllTablesErrors(Map<String, String>) - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
putAllTags(Map<String, String>) - Method in class alluxio.grpc.Metric.Builder
map<string, string> tags = 6;
putAllTotalBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
putAllUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of space used in bytes on all tiers
putAllUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> usedBytesOnTiers = 7;
putAllUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of used bytes on each tier
putAllUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> usedBytesOnTiers = 9;
putAllValues(Map<String, InconsistentPropertyValues>) - Method in class alluxio.grpc.InconsistentProperty.Builder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
putAllWarns(Map<String, InconsistentProperties>) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
putAllXattr(Map<String, ByteString>) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
map<string, bytes> xattr = 6;
putAllXattr(Map<String, ByteString>) - Method in class alluxio.grpc.CreateFilePOptions.Builder
map<string, bytes> xattr = 11;
putAllXattr(Map<String, ByteString>) - Method in class alluxio.grpc.FileInfo.Builder
map<string, bytes> xattr = 32;
putAllXattr(Map<String, ByteString>) - Method in class alluxio.grpc.SetAttributePOptions.Builder
map<string, bytes> xattr = 11;
putAllXattr(Map<String, ByteString>) - Method in class alluxio.grpc.UfsStatus.Builder
map<string, bytes> xattr = 7;
putAllXAttr(Map<String, ByteString>) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
map<string, bytes> xAttr = 19;
putAllXAttr(Map<String, ByteString>) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
map<string, bytes> xAttr = 28;
putAllXAttr(Map<String, ByteString>) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
map<string, bytes> xAttr = 17;
putAllXAttr(Map<String, ByteString>) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Extended attributes, general purpose.
putBlock(long, Block.BlockMeta) - Method in interface alluxio.master.metastore.BlockMetaStore
Adds block metadata to the block store.
putBlock(long, Block.BlockMeta) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
putBlock(long, Block.BlockMeta) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
putCapacityBytesOnTiers(String, long) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
map<string, int64> capacityBytesOnTiers = 2;
putCapacityBytesOnTiers(String, long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> capacityBytesOnTiers = 2;
putCapacityBytesOnTiers(String, long) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> capacityBytesOnTiers = 8;
putClientMetrics(String, List<Metric>) - Method in class alluxio.master.metrics.MetricsStore
Put the metrics from a client with a source name.
putColumn(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.FileStatistics.Builder
map column names to column statistics
putColumnConstraints(String, Domain) - Method in class alluxio.grpc.table.Constraint.Builder
maps column to constraint, columns not present are not constrained
putCurrentBlocksOnTiers(String, TierList) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
putDoraMeta(String, DoraMeta.FileStatus) - Method in interface alluxio.worker.dora.DoraMetaStore
Adds dora metadata to the dora meta store.
putDoraMeta(String, DoraMeta.FileStatus) - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
Stores the metadata identified by URI of the file into this RocksDB.
putErrors(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
putErrors(String, String) - Method in class alluxio.grpc.PolicyStatus.Builder
map<string, string> errors = 10;
putIfAbsent(K, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
putIntByteBuffer(ByteBuffer, int) - Static method in class alluxio.util.io.BufferUtils
Puts a byte (the first byte of an integer) into a ByteBuffer.
putLostStorage(String, StorageList) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of lost storage paths on all tiers
putLostStorage(String, StorageList) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of tier alias to a list of lost storage paths.
putLostStorage(String, StorageList) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
a map from tier alias to the lost storage paths
putMetrics(String, MetricValue) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
putMountPoints(String, MountPointInfo) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
putNewEntry(K, V) - Method in class alluxio.master.metastore.caching.Cache
Writes a key/value pair to the cache.
putObject(String, byte[], long) - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
putObject(String, File, String) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
putObject(String, byte[], long) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
putObject(String, File, String) - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
putObject(String, byte[], long) - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
putObject(String, File, String) - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
putObject(String, byte[], long) - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
putObject(String, File, String) - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
putObject(String, byte[], long) - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
putOptions(String, String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
putPage(PageInfo) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
putParameter(String, String) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
putParameters(String, String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
map<string, string> parameters = 7;
putParameters(String, String) - Method in class alluxio.grpc.table.TableInfo.Builder
map<string, string> parameters = 7;
putPart(ByteBuffer, int) - Method in interface alluxio.underfs.MultipartUploader
Put part as part of a multipart upload.
putPartitionStatistics(String, ColumnStatisticsList) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
putPathConfigs(String, ConfigProperties) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
putProperties(String, String) - Method in class alluxio.grpc.MountPointInfo.Builder
map<string, string> properties = 6;
putProperties(String, String) - Method in class alluxio.grpc.MountPOptions.Builder
map<string, string> properties = 2;
putProperties(String, String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
map<string, string> properties = 2;
putProperties(String, String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
map<string, string> properties = 1;
putProperties(String, String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
map<string, string> properties = 2;
putSerdelibParameters(String, String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
map<string, string> serdelib_parameters = 4;
putSerdeParameters(String, String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
map<string, string> serde_parameters = 5;
putStats(String, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.Layout.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
putStatus(String, boolean) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
map<string, bool> status = 1;
putTablesErrors(String, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
putTag(Fingerprint.Tag, String) - Method in class alluxio.underfs.Fingerprint
Updates a specific tag in the fingerprint.
putTags(String, String) - Method in class alluxio.grpc.Metric.Builder
map<string, string> tags = 6;
putTempFile(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
putTemporary(PageId, byte[]) - Method in interface alluxio.client.file.cache.PageStore
Writes a new temporary page from a source channel to the store.
putTempPage(PageInfo) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
putTimeToFirstBytePerThread(Integer, Map<String, SummaryStatistics>) - Method in class alluxio.stress.client.ClientIOTaskResult
 
putTotalBytesOnTiers(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
putUsedBytesOnTiers(String, long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of space used in bytes on all tiers
putUsedBytesOnTiers(String, long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> usedBytesOnTiers = 7;
putUsedBytesOnTiers(String, long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of used bytes on each tier
putUsedBytesOnTiers(String, long) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> usedBytesOnTiers = 9;
putValues(String, InconsistentPropertyValues) - Method in class alluxio.grpc.InconsistentProperty.Builder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
putWarns(String, InconsistentProperties) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
putWorkerMetrics(String, List<Metric>) - Method in class alluxio.master.metrics.MetricsStore
Put the metrics from a worker with a source name.
putXattr(String, ByteString) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
map<string, bytes> xattr = 6;
putXattr(String, ByteString) - Method in class alluxio.grpc.CreateFilePOptions.Builder
map<string, bytes> xattr = 11;
putXattr(String, ByteString) - Method in class alluxio.grpc.FileInfo.Builder
map<string, bytes> xattr = 32;
putXattr(String, ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
map<string, bytes> xattr = 11;
putXattr(String, ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
map<string, bytes> xattr = 7;
putXAttr(String, ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
map<string, bytes> xAttr = 19;
putXAttr(String, ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
map<string, bytes> xAttr = 28;
putXAttr(String, ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
map<string, bytes> xAttr = 17;
putXAttr(String, ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Extended attributes, general purpose.

Q

QUALIFIED_FILE_FILTER - Static variable in class alluxio.master.job.CopyJob
 
QUALIFIED_FILE_FILTER - Static variable in class alluxio.master.job.LoadJob
 
QUALIFIED_FILE_FILTER - Static variable in class alluxio.master.job.MoveJob
 
query(Message) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
QUERY_KEY_VALUE_SEPARATOR - Static variable in class alluxio.util.URIUtils
 
QUERY_RAW_CONFIGURATION - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
QUERY_RAW_CONFIGURATION - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
QUERY_RAW_CONFIGURATION - Static variable in class alluxio.proxy.AlluxioProxyRestServiceHandler
 
QUERY_RAW_CONFIGURATION - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
QUERY_SEPARATOR - Static variable in class alluxio.util.URIUtils
 
queryGrpcServerAddress() - Method in class alluxio.AbstractClient
AbstractClient works with Grpc Servers.
queryGrpcServerAddress() - Method in class alluxio.AbstractMasterClient
 
quietlyComplete() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Completes this task normally without setting a value.
quietlyCompleteRoot() - Method in class alluxio.concurrent.jsr.CountedCompleter
Equivalent to getRoot().quietlyComplete().
quietlyInvoke() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Commences performing this task and awaits its completion if necessary, without returning its result or throwing its exception.
quietlyJoin() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Joins this task, without returning its result or throwing its exception.
QUORUM_SHELL - Static variable in class alluxio.multi.process.PortCoordination
 
QUORUM_SHELL_INFO - Static variable in class alluxio.multi.process.PortCoordination
 
QUORUM_SHELL_REMOVE - Static variable in class alluxio.multi.process.PortCoordination
 
QuorumCommand - Class in alluxio.cli.fsadmin.journal
Command for seeing/managing quorum state of embedded journal.
QuorumCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.journal.QuorumCommand
 
QuorumElectCommand - Class in alluxio.cli.fsadmin.journal
Command for transferring the leadership to another master within a quorum.
QuorumElectCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
QuorumInfoCommand - Class in alluxio.cli.fsadmin.journal
Command for querying journal quorum information.
QuorumInfoCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
QuorumRemoveCommand - Class in alluxio.cli.fsadmin.journal
Command for removing a server from journal quorum.
QuorumRemoveCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
QuorumServerInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.QuorumServerInfo
QuorumServerInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.QuorumServerInfo
QuorumServerInfoOrBuilder - Interface in alluxio.grpc
 
QuorumServerState - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.journal.QuorumServerState
QuotaPageMetaStore - Class in alluxio.client.file.cache
A metastore implementation that tracking usage associated with each cache scope.
QuotaPageMetaStore(CacheEvictorOptions, List<PageStoreDir>) - Constructor for class alluxio.client.file.cache.QuotaPageMetaStore
 

R

RAFT_ADDRESSES_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
RAFT_ADDRESSES = 12;
RAFT_DIR - Static variable in class alluxio.master.journal.raft.RaftJournalUtils
 
RAFT_GROUP_ID - Static variable in class alluxio.master.journal.raft.RaftJournalSystem
 
RAFT_GROUP_UUID - Static variable in class alluxio.master.journal.raft.RaftJournalSystem
 
RAFT_JOURNAL_SERVICE_NAME - Static variable in class alluxio.Constants
 
RAFT_JOURNAL_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
RAFT_JOURNAL_SERVICE = 16;
RAFT_JOURNAL_SERVICE_VERSION - Static variable in class alluxio.Constants
 
RAFT_JOURNAL_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
RAFT_JOURNAL = 11;
RAFTADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
RaftJournal - Class in alluxio.master.journal.raft
Class associated with each master that lets the master create journal contexts for writing entries to the journal.
RaftJournal(Journaled, URI, AtomicReference<AsyncJournalWriter>) - Constructor for class alluxio.master.journal.raft.RaftJournal
 
RAFTJOURNAL_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
RaftJournalAppender - Class in alluxio.master.journal.raft
A client to append messages to RAFT log state.
RaftJournalAppender(RaftServer, Supplier<RaftClient>, ClientId) - Constructor for class alluxio.master.journal.raft.RaftJournalAppender
 
RaftJournalDumper - Class in alluxio.master.journal.tool
Implementation of AbstractJournalDumper for RAFT journals.
RaftJournalDumper(String, long, long, String, String) - Constructor for class alluxio.master.journal.tool.RaftJournalDumper
Creates embedded journal dumper.
RaftJournalProgressLogger - Class in alluxio.master.journal.raft
Logs journal replay progress for the RaftJournalSystem.
RaftJournalProgressLogger(JournalStateMachine, OptionalLong) - Constructor for class alluxio.master.journal.raft.RaftJournalProgressLogger
Creates a new instance of the logger.
RaftJournalProto - Class in alluxio.grpc
 
RaftJournalServiceClient - Class in alluxio.master.journal.raft
A client for raft journal service.
RaftJournalServiceClient(MasterSelectionPolicy, Supplier<RetryPolicy>) - Constructor for class alluxio.master.journal.raft.RaftJournalServiceClient
Create a client that talks to a specific master.
RaftJournalServiceGrpc - Class in alluxio.grpc
This interface contains raft service endpoints for Alluxio masters.
RaftJournalServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains raft service endpoints for Alluxio masters.
RaftJournalServiceGrpc.RaftJournalServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service RaftJournalService.
RaftJournalServiceGrpc.RaftJournalServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service RaftJournalService.
RaftJournalServiceGrpc.RaftJournalServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service RaftJournalService.
RaftJournalServiceGrpc.RaftJournalServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service RaftJournalService.
RaftJournalServiceHandler - Class in alluxio.master.journal.raft
RPC handler for raft journal service.
RaftJournalServiceHandler(StateMachineStorage) - Constructor for class alluxio.master.journal.raft.RaftJournalServiceHandler
 
RaftJournalServiceImplBase() - Constructor for class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceImplBase
 
RaftJournalSystem - Class in alluxio.master.journal.raft
System for multiplexing many logical journals into a single raft-based journal.
RaftJournalSystem(URI, NetworkAddressUtils.ServiceType) - Constructor for class alluxio.master.journal.raft.RaftJournalSystem
RaftJournalUtils - Class in alluxio.master.journal.raft
Helper class for raft journal operations.
RaftJournalWriter - Class in alluxio.master.journal.raft
Class for writing entries to the Raft journal.
RaftJournalWriter(long, RaftJournalAppender) - Constructor for class alluxio.master.journal.raft.RaftJournalWriter
 
RaftPrimarySelector - Class in alluxio.master.journal.raft
A primary selector backed by a Raft consensus cluster.
RaftPrimarySelector() - Constructor for class alluxio.master.journal.raft.RaftPrimarySelector
 
RaftSnapshotManager - Class in alluxio.master.journal.raft
Manages a snapshot download.
RamDiskMountPrivilegeValidationTask - Class in alluxio.cli
Task for validating whether worker has enough privilege to mount RAM disk.
RamDiskMountPrivilegeValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.RamDiskMountPrivilegeValidationTask
Creates a new instance of RamDiskMountPrivilegeValidationTask for validating mount privilege.
randomAlphaNumString(int) - Static method in class alluxio.util.CommonUtils
Generates a random alphanumeric string of the given length.
randomBytes(int) - Static method in class alluxio.util.CommonUtils
Generates a random byte array of the given length.
Range - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Range
Range.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Range
RANGE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Domain
 
RangeFileInStream - Class in alluxio.proxy.s3
This class is use FileInStream underlying, and implement range read.
RangeFileInStream.Factory - Class in alluxio.proxy.s3
Factory for RangeFileInStream.
RangeOrBuilder - Interface in alluxio.grpc.table
 
RANGES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.RangeSet
 
RangeSet - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.RangeSet
RangeSet.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.RangeSet
RangeSetOrBuilder - Interface in alluxio.grpc.table
 
RateLimiter - Interface in alluxio.util
Used to limit the rate of operations.
RateLimitInputStream - Class in alluxio.proxy.s3
This class is a wrapper for InputStream which limit rate when reading bytes.
RateLimitInputStream(InputStream, RateLimiter...) - Constructor for class alluxio.proxy.s3.RateLimitInputStream
Constructs a new RateLimitInputStream.
RatisDropwizardExports - Class in alluxio.metrics.sink
Collect Dropwizard metrics, but rename ratis specific metrics.
RatisDropwizardExports(MetricRegistry) - Constructor for class alluxio.metrics.sink.RatisDropwizardExports
Creates a new DropwizardExports with a DefaultSampleBuilder.
RatisNameRewriteSampleBuilder - Class in alluxio.metrics.sink
Collect Dropwizard metrics and rename ratis specific metrics.
RatisNameRewriteSampleBuilder() - Constructor for class alluxio.metrics.sink.RatisNameRewriteSampleBuilder
 
RAWVALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigurationPOptions
 
read(byte[], int, int) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
read(ByteBuffer, int, int) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
read() - Method in class alluxio.client.file.FileInStream
 
read(byte[]) - Method in class alluxio.client.file.FileInStream
 
read(byte[], int, int) - Method in class alluxio.client.file.FileInStream
 
read(ByteBuffer) - Method in class alluxio.client.file.FileInStream
Reads up to buf.remaining() bytes into buf.
read(ByteBuffer, int, int) - Method in class alluxio.client.file.FileInStream
Reads up to len bytes of data from the input stream into the byte buffer.
read(byte[], int, int) - Method in class alluxio.client.file.PositionReadFileInStream
 
read(ByteBuffer, int, int) - Method in class alluxio.client.file.PositionReadFileInStream
 
read() - Method in class alluxio.client.file.ufs.UfsFileInStream
 
read(ByteBuffer, int, int) - Method in class alluxio.client.file.ufs.UfsFileInStream
 
read(byte[], int, int) - Method in class alluxio.client.file.ufs.UfsFileInStream
 
read(String, ByteBuffer, long, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
read(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
read(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FuseFileInStream
 
read(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FuseFileOutStream
 
read(ByteBuffer, long, long) - Method in interface alluxio.fuse.file.FuseFileStream
Reads data from the stream.
read(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FusePositionReader
 
read(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
read(String, ByteBuffer, long, long, FuseFileInfo) - Method in class alluxio.fuse.StackFS
 
read(byte[]) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
read(byte[], int, int) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
read() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
read(ByteBuffer) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
read() - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
read(byte[]) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
read(byte[], int, int) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
read(ByteBuffer) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
read(long, byte[], int, int) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
read(String, ByteBuffer, long, long, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
read() - Method in interface alluxio.master.journalv0.JournalInputStream
Reads the next journal entry.
read(long, byte[], int) - Method in interface alluxio.PositionReader
 
read(long, byte[], int, int) - Method in interface alluxio.PositionReader
 
read(long, ByteBuffer, int) - Method in interface alluxio.PositionReader
 
read(long, ByteBuf, int) - Method in interface alluxio.PositionReader
 
read(long, ReadTargetBuffer, int) - Method in interface alluxio.PositionReader
 
read() - Method in class alluxio.proxy.s3.RangeFileInStream
 
read(byte[]) - Method in class alluxio.proxy.s3.RangeFileInStream
 
read(byte[], int, int) - Method in class alluxio.proxy.s3.RangeFileInStream
 
read(ByteBuffer, int, int) - Method in class alluxio.proxy.s3.RangeFileInStream
Reads up to len bytes of data from the input stream into the byte buffer.
read() - Method in class alluxio.proxy.s3.RateLimitInputStream
 
read(byte[]) - Method in class alluxio.proxy.s3.RateLimitInputStream
 
read(byte[], int, int) - Method in class alluxio.proxy.s3.RateLimitInputStream
 
READ - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
read(Integer) - Method in class alluxio.proxy.StreamsRestServiceHandler
 
read() - Method in class alluxio.s3.ChunkedEncodingInputStream
 
read(byte[], int, int) - Method in class alluxio.s3.ChunkedEncodingInputStream
 
read() - Method in class alluxio.s3.MultiChunkEncodingInputStream
 
read(byte[], int, int) - Method in class alluxio.s3.MultiChunkEncodingInputStream
 
read() - Method in class alluxio.underfs.cephfs.CephInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.cephfs.CephInputStream
 
read() - Method in class alluxio.underfs.gcs.GCSInputStream
 
read(byte[]) - Method in class alluxio.underfs.gcs.GCSInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.gcs.GCSInputStream
 
read() - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
 
read(byte[]) - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
 
read() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
read(byte[]) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
If there has been a number of sequential reads in a row, we move to regular buffered reads.
read() - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read(byte[]) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read() - Method in class alluxio.underfs.s3a.S3AInputStream
 
read(byte[]) - Method in class alluxio.underfs.s3a.S3AInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.s3a.S3AInputStream
 
read(ByteBuffer, long, long, FileId, String, UfsReadOptions) - Method in class alluxio.underfs.UfsIOManager
Read from ufs.
read(Path, InputStream) - Method in interface alluxio.util.compression.DirectoryMarshaller
Reads the content from the inputStream and writes them to the specified path.
read(Path, InputStream) - Method in class alluxio.util.compression.GzipMarshaller
 
read(Path, InputStream) - Method in class alluxio.util.compression.NoCompressionMarshaller
 
read(Path, InputStream) - Method in class alluxio.util.compression.TarGzMarshaller
 
read(ByteBuffer) - Method in class alluxio.worker.block.io.BlockReadableChannel
 
read(long, long) - Method in class alluxio.worker.block.io.BlockReader
Reads data from the block.
read(long, long) - Method in class alluxio.worker.dora.PagedFileReader
 
READ_EXECUTE_VALUE - Static variable in enum alluxio.grpc.Bits
READ_EXECUTE = 6;
READ_ONLY_VALUE - Static variable in enum alluxio.grpc.UfsPMode
READ_ONLY = 2;
READ_ONLY_VALUE - Static variable in enum alluxio.proto.journal.File.UfsMode
READ_ONLY = 1;
READ_TYPE_FLAG_OPTION_NAME - Static variable in class alluxio.stress.common.FileSystemParameters
 
READ_VALUE - Static variable in enum alluxio.grpc.Bits
READ = 5;
Read_VALUE - Static variable in enum alluxio.grpc.PAclAction
Read = 0;
READ_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclAction
READ = 0;
READ_WRITE_VALUE - Static variable in enum alluxio.grpc.Bits
READ_WRITE = 7;
READ_WRITE_VALUE - Static variable in enum alluxio.grpc.UfsPMode
READ_WRITE = 3;
READ_WRITE_VALUE - Static variable in enum alluxio.proto.journal.File.UfsMode
READ_WRITE = 2;
readableBytes() - Method in class alluxio.grpc.ReadableDataBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
readableBytes() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
ReadableDataBuffer - Class in alluxio.grpc
Class for making wrapping ReadableBuffer as DataBuffer.
ReadableDataBuffer(ReadableBuffer) - Constructor for class alluxio.grpc.ReadableDataBuffer
Creates DataBuffer for reading.
readBlock(StreamObserver<ReadResponse>) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Reads a block from the worker.
readBlock(StreamObserver<ReadResponse>) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
readBlock(StreamObserver<ReadResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
readBlock(StreamObserver<ReadResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
readBlock(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the path to the block file in local storage.
readBlock(StreamObserver<ReadResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
readBlockNoDataBack(ReadRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Reads a block with getting actual data.
readBlockNoDataBack(ReadRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
readBlockRemote(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the block reader for the block.
readByte(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific byte value from the input byte array at the given offset.
readByte(ByteBuffer, int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific byte value from the input byte buffer at the given offset.
readBytes(ByteBuffer) - Method in class alluxio.grpc.ReadableDataBuffer
 
readBytes(byte[], int, int) - Method in class alluxio.grpc.ReadableDataBuffer
 
readBytes(OutputStream, int) - Method in class alluxio.grpc.ReadableDataBuffer
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
readBytes(OutputStream, int) - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
readBytes(ByteBuffer) - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
readBytes(byte[], int, int) - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Transfers this buffer's data to the specified destination starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= length).
readBytes(OutputStream, int) - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Transfers this buffer's data to the given stream.
readBytes(ByteBuffer) - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Transfers this buffer's data to the given ByteBuffer.
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readBytes(OutputStream, int) - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readBytes(ByteBuffer) - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readBytes(OutputStream, int) - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readBytes(ByteBuffer) - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
readBytes(OutputStream, int) - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
readBytes(ByteBuffer) - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
readCallback(String, ByteBuffer, long, long, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
readCheckpoint(CheckpointInputStream, Path) - Method in class alluxio.master.journal.tool.AbstractJournalDumper
Used to read checkpoint streams.
readChunk() - Method in class alluxio.client.block.stream.BlockWorkerDataReader
 
readChunk(int) - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
Reads a specific chunk from the block.
readChunk() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
Reads a chunk of data.
readChunk() - Method in interface alluxio.client.block.stream.DataReader
Reads a chunk.
readChunk() - Method in class alluxio.client.block.stream.GrpcDataReader
 
readChunk() - Method in class alluxio.client.block.stream.NettyDataReader
 
readChunk() - Method in class alluxio.client.block.stream.SharedGrpcDataReader
 
readdir(String, long, long, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
readdir(String, long, long, long, FuseFileInfo) - Method in class alluxio.fuse.StackFS
 
readdir(String, long, long, long, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
readdirCallback(String, long, long, long, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
readEntry() - Method in class alluxio.master.journal.JournalEntryStreamReader
Reads a journal entry from the input stream.
READER_EXECUTOR - Static variable in class alluxio.worker.grpc.GrpcExecutors
 
READER_EXECUTOR - Static variable in class alluxio.worker.netty.NettyExecutors
 
READER_SERIALIZED_RUNNER_EXECUTOR - Static variable in class alluxio.worker.grpc.GrpcExecutors
 
readFromFile(RandomAccessFile, int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
readFromFile(RandomAccessFile, int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
readFromFile(RandomAccessFile, int) - Method in class alluxio.file.NettyBufTargetBuffer
 
readFromFile(RandomAccessFile, int) - Method in interface alluxio.file.ReadTargetBuffer
 
readFromInputStream(InputStream, int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
readFromInputStream(InputStream, int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
readFromInputStream(InputStream, int) - Method in class alluxio.file.NettyBufTargetBuffer
 
readFromInputStream(InputStream, int) - Method in interface alluxio.file.ReadTargetBuffer
 
readFully(long, byte[]) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
readFully(long, byte[], int, int) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
readInt(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific integer byte value (4 bytes) from the input byte array at the given offset.
readInt(ByteBuffer, int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific integer byte value (4 bytes) from the input byte buffer at the given offset.
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.client.file.cache.LocalCachePositionReader
 
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.client.file.dora.DoraCachePositionReader
 
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.client.file.dora.netty.NettyDataReader
 
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.hadoop.AlluxioHdfsPositionReader
 
readInternal(long, ReadTargetBuffer, int) - Method in interface alluxio.PositionReader
 
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.underfs.local.LocalPositionReader
 
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.underfs.ObjectPositionReader
 
readInternal(long, ReadTargetBuffer, int) - Method in class alluxio.worker.dora.PagedFileReader
 
readLock(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Non-exclusively acquires the locks of two buckets, blocking if necessary until available.
readLock() - Method in class alluxio.concurrent.ClientRWLock
 
readLong(byte[], int) - Static method in class alluxio.master.metastore.rocks.RocksUtils
 
readLong(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific long byte value (8 bytes) from the input byte array at the given offset.
readNodeList(String, String) - Static method in class alluxio.cli.CommandUtils
Reads a list of nodes from given file name ignoring comments and empty lines.
readObject(BufferInput<?>, Serializer) - Method in class alluxio.master.backup.BackupHandshakeMessage
 
readObject(BufferInput<?>, Serializer) - Method in class alluxio.master.backup.BackupHeartbeatMessage
 
readObject(BufferInput<?>, Serializer) - Method in class alluxio.master.backup.BackupRequestMessage
 
readObject(BufferInput<?>, Serializer) - Method in class alluxio.master.backup.BackupSuspendMessage
 
READONLY_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
READONLY_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPOptions
 
READONLY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
ReadOnlyInodeStore - Interface in alluxio.master.metastore
Read-only access to the inode store.
ReadOption - Class in alluxio.master.metastore
Options for reading from the inode store.
ReadOption.Builder - Class in alluxio.master.metastore
Builder for ReadOption.
readPartition() - Method in class alluxio.examples.Performance.AlluxioReadWorker
Reads a partition.
ReadPType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.ReadPType
readRawVarint32(int, InputStream) - Static method in class alluxio.util.proto.ProtoUtils
A wrapper of CodedInputStream.readRawVarint32(InputStream).
readRawVarint32(InputStream) - Static method in class alluxio.util.proto.ProtoUtils
A wrapper of CodedInputStream.readRawVarint32(InputStream).
ReadRequest - Class in alluxio.grpc
The read request.
ReadRequest - Class in alluxio.worker.netty
Represents a read request received from netty channel.
ReadRequest(long, long, long, int) - Constructor for class alluxio.worker.netty.ReadRequest
 
ReadRequest.Builder - Class in alluxio.grpc
The read request.
ReadRequestContext<T extends ReadRequest> - Class in alluxio.worker.netty
Represents the context of a read request received from netty channel.
ReadRequestContext(T) - Constructor for class alluxio.worker.netty.ReadRequestContext
 
ReadRequestOrBuilder - Interface in alluxio.grpc
 
ReadResponse - Class in alluxio.grpc
The read response.
ReadResponse.Builder - Class in alluxio.grpc
The read response.
ReadResponseMarshaller - Class in alluxio.grpc
Marshaller for ReadResponse.
ReadResponseMarshaller() - Constructor for class alluxio.grpc.ReadResponseMarshaller
ReadResponseOrBuilder - Interface in alluxio.grpc
 
readShort(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific short byte value (2 bytes) from the input byte array at the given offset.
readTable(String, String, Constraint) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
readTable(String, String, Constraint) - Method in interface alluxio.client.table.TableMasterClient
Returns metadata for reading a table given constraints.
readTable(ReadTablePRequest, StreamObserver<ReadTablePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
 
readTable(ReadTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
 
readTable(ReadTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
 
readTable(ReadTablePRequest, StreamObserver<ReadTablePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
ReadTablePRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ReadTablePRequest
ReadTablePRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ReadTablePRequest
ReadTablePRequestOrBuilder - Interface in alluxio.grpc.table
 
ReadTablePResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ReadTablePResponse
ReadTablePResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.ReadTablePResponse
ReadTablePResponseOrBuilder - Interface in alluxio.grpc.table
 
readTag(int, int) - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
Reads the value of tag in specified position.
readTag(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
ReadTargetBuffer - Interface in alluxio.file
TargetBuffer for zero-copy read from page store.
readTarGz(Path, InputStream) - Static method in class alluxio.util.compression.TarUtils
Reads a gzipped tar archive from a stream and writes it to the given path.
ReadType - Enum in alluxio.client
Convenience modes for commonly used read types.
READTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
 
readUfsBlock(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets a block reader to read a UFS block.
receive(long) - Method in class alluxio.client.block.stream.GrpcBlockingStream
Receives a response from the server.
receive(long) - Method in class alluxio.client.block.stream.GrpcDataMessageBlockingStream
 
receiveDataMessage(long) - Method in class alluxio.client.block.stream.GrpcDataMessageBlockingStream
Receives a response with data buffer from the server.
RECENT_LENGTH - Static variable in class alluxio.job.wire.JobServiceSummary
 
RECENTACTIVITIES_FIELD_NUMBER - Static variable in class alluxio.grpc.JobServiceSummary
 
RECENTFAILURES_FIELD_NUMBER - Static variable in class alluxio.grpc.JobServiceSummary
 
Reconfigurable - Interface in alluxio.conf
Reconfigurable listener.
ReconfigurableRegistry - Class in alluxio.conf
Registry of all reconfigurable listeners.
record(long) - Method in class alluxio.job.util.TimeSeries
Record one event at a timestamp into the time series.
record(long, int) - Method in class alluxio.job.util.TimeSeries
Record events at a timestamp into the time series.
record(String, double) - Method in class alluxio.master.metrics.TimeSeriesStore
Records a value for the given metric at the current time.
record(double) - Method in class alluxio.metrics.TimeSeries
Record a value at the current time.
record(String) - Method in class alluxio.recorder.NoopRecorder
 
record(String, Object...) - Method in class alluxio.recorder.NoopRecorder
 
record(String) - Method in class alluxio.recorder.Recorder
Records a message.
record(String, Object...) - Method in class alluxio.recorder.Recorder
Records a message with a format template and arguments.
Recorder - Class in alluxio.recorder
A tool for recording information, which can be used to record the process of execution.
Recorder() - Constructor for class alluxio.recorder.Recorder
Constructs a new instance.
recordStartSync() - Method in class alluxio.master.file.meta.UfsSyncPathCache
Called when starting a sync.
recordTimeInQ() - Method in class alluxio.scheduler.job.Task.TaskStat
Record time when task is inside the queue.
recordTimeToComplete() - Method in class alluxio.scheduler.job.Task.TaskStat
Record time taken to complete the task.
recordWorkerRegistration(long) - Method in class alluxio.master.block.DefaultBlockMaster
Re-register a lost worker or complete registration after getting a worker id.
recover() - Method in interface alluxio.master.journalv0.JournalWriter
Recovers the checkpoint in case the master crashed while updating it previously.
recover() - Method in class alluxio.master.journalv0.ufs.UfsCheckpointManager
Recovers the checkpoint in case the master crashed while updating it.
recover() - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
reCreateReinitialize(FileSystemContextReinitializer) - Method in class alluxio.client.file.FileSystemContext
 
RECURSIVE - Static variable in class alluxio.underfs.options.DeleteOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.FreePOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadMetadataPOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
RECURSIVE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAclEntry
 
recursiveListLocalDir(File) - Static method in class alluxio.util.CommonUtils
Recursively lists a local dir and all its subdirs and return all the files.
reduceList(Iterable<IOTaskResult>) - Static method in class alluxio.stress.worker.IOTaskResult
Reduce a list of IOTaskResult into one.
ref() - Method in class alluxio.client.block.stream.BufferCachingGrpcDataReader
Increases the reference count and return the current count.
RefCountLockResource - Class in alluxio.resource
Reference counted Lock resource, automatically unlocks and decrements the reference count.
RefCountLockResource(ReentrantReadWriteLock, LockMode, boolean, AtomicInteger, boolean) - Constructor for class alluxio.resource.RefCountLockResource
Creates a new instance of LockResource using the given lock and reference counter.
REFERENCE - Static variable in class alluxio.conf.Source
 
ReferenceProperty - Interface in alluxio.conf.reference
This interface is used to define the reference properties.
refresh() - Method in class alluxio.cli.ValidationToolRegistry
Refreshes the registry by service loading classes.
refresh(List<BlockWorkerInfo>, int) - Method in class alluxio.client.file.dora.ConsistentHashProvider
Initializes or refreshes the worker list using the given list of workers and number of virtual nodes.
RefreshPolicy - Interface in alluxio.refresh
Policy for determining whether a refresh should be performed.
refreshTemporaryToken(byte[]) - Method in interface alluxio.underfs.UnderFileSystem
Refreshes the old temporary token.
regenerateReport() - Method in class alluxio.master.meta.checkconf.ConfigurationChecker
Checks the server-side configurations and records the check results.
REGEX_STRING - Static variable in class alluxio.conf.PropertyKey
Regex string to find "${key}" for variable substitution.
RegexMetricFilter - Class in alluxio.metrics.sink
A regex metrics filter.
RegexMetricFilter(Properties) - Constructor for class alluxio.metrics.sink.RegexMetricFilter
Creates a new RegexMetricFilter with a Properties.
register(PropertyKey) - Static method in class alluxio.conf.PropertyKey
Registers the given key to the global key map.
register(Reconfigurable) - Static method in class alluxio.conf.ReconfigurableRegistry
Add a listener.
register(T) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Registers a new factory.
register(StorageTierAssoc, List<String>, Map<String, Long>, Map<String, Long>, Set<Long>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Marks the worker as registered, while updating all of its metadata.
register(long) - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
Registers with the leader master.
register(long, List<ConfigProperty>) - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
Registers with the leader master.
register(MetricKey) - Static method in class alluxio.metrics.MetricKey
Registers the given key to the global key map.
register(UnderFileSystemFactory) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Registers a new factory.
register(long, List<String>, Map<String, Long>, Map<String, Long>, Map<BlockStoreLocation, List<Long>>, Map<String, List<String>>, List<ConfigProperty>) - Method in class alluxio.worker.block.BlockMasterClient
The method the worker should execute to register with the block master.
Register_VALUE - Static variable in enum alluxio.grpc.CommandType
Ask the worker to re-register.
registerAggregatedCachedGaugeIfAbsent(String, Set<MetricKey>, long, TimeUnit) - Static method in class alluxio.metrics.MetricsSystem
Created a gauge that aggregates the value of existing gauges.
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.AuthenticationServerProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.AuthenticationServerProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.BlockMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.BlockWorkerProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.BlockWorkerProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.CommonProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.CommonProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.FileSystemMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.FileSystemMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.FsCommonProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.FsCommonProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.JobMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.JobMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.JournalMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.JournalMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.MessagingTransportProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.MessagingTransportProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.MetaMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.MetaMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.MetricMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.MetricMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.PolicyMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.PolicyMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.RaftJournalProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.RaftJournalProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.table.layout.hive.HiveLayoutProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.table.layout.hive.HiveLayoutProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.table.TableMasterProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.table.TableMasterProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.grpc.VersionProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.grpc.VersionProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.client.Cache
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.client.Cache
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.dataserver.Protocol
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.dataserver.Protocol
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Block
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Block
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.journal.File
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.File
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Job
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Job
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Journal
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Journal
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Meta
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Meta
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.journal.Policy
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.journal.Policy
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.meta.Block
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.meta.Block
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.meta.DoraMeta
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.meta.DoraMeta
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.meta.InodeMeta
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.meta.InodeMeta
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.shared.Acl
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.shared.Acl
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class alluxio.proto.status.Status
 
registerAllExtensions(ExtensionRegistry) - Static method in class alluxio.proto.status.Status
 
registerAndStartSync(DefaultServiceEntity) - Method in class alluxio.membership.ServiceDiscoveryRecipe
Register service and start keeping-alive.
registerBlockForDeletion(long) - Method in interface alluxio.master.file.BlockDeletionContext
 
registerBlockForDeletion(long) - Method in class alluxio.master.file.DefaultBlockDeletionContext
 
registerBlockForDeletion(long) - Method in class alluxio.master.file.NoopBlockDeletionContext
 
registerBlocksForDeletion(Collection<Long>) - Method in interface alluxio.master.file.BlockDeletionContext
 
registerBlocksForDeletion(Collection<Long>) - Method in class alluxio.master.file.DefaultBlockDeletionContext
 
registerBlockStoreEventListener(BlockStoreEventListener) - Method in interface alluxio.worker.block.BlockStore
Registers a BlockStoreEventListener to this block store.
registerCachedGaugeIfAbsent(String, Gauge<T>) - Static method in class alluxio.metrics.MetricsSystem
Registers a cached gauge if it has not been registered.
registerCachedGaugeIfAbsent(String, Gauge<T>, long, TimeUnit) - Static method in class alluxio.metrics.MetricsSystem
Registers a cached gauge if it has not been registered.
registerChangeListener(Runnable) - Method in class alluxio.master.meta.checkconf.ConfigurationStore
Registers callback functions to use when this store has any changes.
registerChannel(UUID, AuthenticatedUserInfo, AuthenticatedChannelServerDriver) - Method in interface alluxio.security.authentication.AuthenticationServer
Registers new user against given channel.
registerChannel(UUID, AuthenticatedUserInfo, AuthenticatedChannelServerDriver) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
registerCommand(String, ShellCommand, ShellCommand) - Method in class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
 
RegisterCommand - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterCommand
RegisterCommand.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterCommand
REGISTERCOMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobCommand
 
RegisterCommandOrBuilder - Interface in alluxio.grpc
 
registerCommands() - Method in class alluxio.cli.bundler.command.CollectAlluxioInfoCommand
 
registerCommands() - Method in class alluxio.cli.bundler.command.CollectEnvCommand
 
registerCommands() - Method in class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
 
registerGaugeIfAbsent(String, Gauge<T>) - Static method in class alluxio.metrics.MetricsSystem
Registers a gauge if it has not been registered.
registerGauges(DefaultBlockMaster) - Static method in class alluxio.master.block.DefaultBlockMaster.Metrics
Registers metric gauges.
registerGauges(UfsManager, InodeTree) - Static method in class alluxio.master.file.DefaultFileSystemMaster.Metrics
Register some file system master related gauges.
RegisterJobMasterPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobMasterPOptions
RegisterJobMasterPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobMasterPOptions
RegisterJobMasterPOptionsOrBuilder - Interface in alluxio.grpc
 
RegisterJobMasterPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobMasterPRequest
RegisterJobMasterPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobMasterPRequest
RegisterJobMasterPRequestOrBuilder - Interface in alluxio.grpc
 
RegisterJobMasterPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobMasterPResponse
RegisterJobMasterPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobMasterPResponse
RegisterJobMasterPResponseOrBuilder - Interface in alluxio.grpc
 
registerJobWorker(RegisterJobWorkerPRequest, StreamObserver<RegisterJobWorkerPResponse>) - Method in interface alluxio.grpc.JobMasterWorkerServiceGrpc.AsyncService
Returns a worker id for the given network address.
registerJobWorker(RegisterJobWorkerPRequest) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceBlockingStub
Returns a worker id for the given network address.
registerJobWorker(RegisterJobWorkerPRequest) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceFutureStub
Returns a worker id for the given network address.
registerJobWorker(RegisterJobWorkerPRequest, StreamObserver<RegisterJobWorkerPResponse>) - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceStub
Returns a worker id for the given network address.
registerJobWorker(RegisterJobWorkerPRequest, StreamObserver<RegisterJobWorkerPResponse>) - Method in class alluxio.master.job.JobMasterWorkerServiceHandler
 
RegisterJobWorkerPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobWorkerPOptions
RegisterJobWorkerPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobWorkerPOptions
RegisterJobWorkerPOptionsOrBuilder - Interface in alluxio.grpc
 
RegisterJobWorkerPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobWorkerPRequest
RegisterJobWorkerPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobWorkerPRequest
RegisterJobWorkerPRequestOrBuilder - Interface in alluxio.grpc
 
RegisterJobWorkerPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobWorkerPResponse
RegisterJobWorkerPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RegisterJobWorkerPResponse
RegisterJobWorkerPResponseOrBuilder - Interface in alluxio.grpc
 
RegisterLease - Class in alluxio.wire
A RegisterLease is what the master uses to control the concurrency of worker registration.
RegisterLease(long) - Constructor for class alluxio.wire.RegisterLease
Constructor.
RegisterLeaseManager - Class in alluxio.master.block
The manager for RegisterLease that manages the lifecycle for the leases.
RegisterLeaseManager() - Constructor for class alluxio.master.block.RegisterLeaseManager
Constructor.
RegisterLeaseNotFoundException - Exception in alluxio.exception
The exception thrown when the worker attempts to register but there is no lease found.
RegisterLeaseNotFoundException(String) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified detail message.
RegisterLeaseNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified detail message and cause.
RegisterLeaseNotFoundException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified exception message and multiple parameters.
RegisterLeaseNotFoundException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
registerLostWorkerFoundListener(Consumer<Address>) - Method in interface alluxio.master.block.BlockMaster
Registers callback functions to use when lost workers become alive.
registerLostWorkerFoundListener(Consumer<Address>) - Method in class alluxio.master.block.DefaultBlockMaster
 
registerMaster(RegisterJobMasterPRequest, StreamObserver<RegisterJobMasterPResponse>) - Method in interface alluxio.grpc.JobMasterMasterServiceGrpc.AsyncService
Registers a master.
registerMaster(RegisterJobMasterPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceBlockingStub
Registers a master.
registerMaster(RegisterJobMasterPRequest) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceFutureStub
Registers a master.
registerMaster(RegisterJobMasterPRequest, StreamObserver<RegisterJobMasterPResponse>) - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceStub
Registers a master.
registerMaster(RegisterMasterPRequest, StreamObserver<RegisterMasterPResponse>) - Method in interface alluxio.grpc.MetaMasterMasterServiceGrpc.AsyncService
Registers a master.
registerMaster(RegisterMasterPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceBlockingStub
Registers a master.
registerMaster(RegisterMasterPRequest) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceFutureStub
Registers a master.
registerMaster(RegisterMasterPRequest, StreamObserver<RegisterMasterPResponse>) - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceStub
Registers a master.
registerMaster(RegisterJobMasterPRequest, StreamObserver<RegisterJobMasterPResponse>) - Method in class alluxio.master.meta.JobMasterMasterServiceHandler
 
registerMaster(RegisterMasterPRequest, StreamObserver<RegisterMasterPResponse>) - Method in class alluxio.master.meta.MetaMasterMasterServiceHandler
 
RegisterMasterPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RegisterMasterPOptions
RegisterMasterPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RegisterMasterPOptions
RegisterMasterPOptionsOrBuilder - Interface in alluxio.grpc
 
RegisterMasterPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RegisterMasterPRequest
RegisterMasterPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RegisterMasterPRequest
RegisterMasterPRequestOrBuilder - Interface in alluxio.grpc
 
RegisterMasterPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RegisterMasterPResponse
RegisterMasterPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RegisterMasterPResponse
RegisterMasterPResponseOrBuilder - Interface in alluxio.grpc
 
registerMetrics() - Static method in class alluxio.client.file.cache.LocalCacheFileInStream
Registers metrics.
registerMetrics() - Method in class alluxio.master.journal.AbstractJournalSystem
 
registerNewConf(Address, List<ConfigProperty>) - Method in class alluxio.master.meta.checkconf.ConfigurationStore
Registers new configuration information.
registerNewWorkerConfListener(BiConsumer<Address, List<ConfigProperty>>) - Method in interface alluxio.master.block.BlockMaster
Registers callback functions to use when workers register with configuration.
registerNewWorkerConfListener(BiConsumer<Address, List<ConfigProperty>>) - Method in class alluxio.master.block.DefaultBlockMaster
 
registerRatisMetricReporters(Map<String, RatisDropwizardExports>) - Static method in class alluxio.metrics.sink.RatisDropwizardExports
Register ratis metric to metricRegistry.
registerService(SimpleService) - Method in class alluxio.master.MasterProcess
Used in master factory after instantiating the master process and before starting the master process.
RegisterStreamer - Class in alluxio.worker.block
This class oversees the logic of registering with the master using a stream of RegisterWorkerPRequest.
RegisterStreamer(BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub, long, List<String>, Map<String, Long>, Map<String, Long>, Map<BlockStoreLocation, List<Long>>, Map<String, List<String>>, List<ConfigProperty>) - Constructor for class alluxio.worker.block.RegisterStreamer
Constructor.
RegisterStreamer(BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub, long, List<String>, Map<String, Long>, Map<String, Long>, Map<BlockStoreLocation, List<Long>>, Map<String, List<String>>, List<ConfigProperty>, BuildVersion) - Constructor for class alluxio.worker.block.RegisterStreamer
Constructor.
RegisterStreamer(BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub, long, List<String>, Map<String, Long>, Map<String, Long>, Map<String, List<String>>, List<ConfigProperty>, BlockMapIterator) - Constructor for class alluxio.worker.block.RegisterStreamer
Constructor.
RegisterStreamObserver - Class in alluxio.master.block
This class handles the master side logic of the register stream.
RegisterStreamObserver(BlockMaster, StreamObserver<RegisterWorkerPResponse>) - Constructor for class alluxio.master.block.RegisterStreamObserver
Constructor.
registerThroughputGauge(String, String) - Method in class alluxio.master.metrics.DefaultMetricsMaster
Registers the corresponding throughput of the given counter.
registerWithMaster() - Method in class alluxio.worker.block.RegisterStreamer
Manages the logic of registering with the master in a stream.
registerWithStream(long, List<String>, Map<String, Long>, Map<String, Long>, Map<BlockStoreLocation, List<Long>>, Map<String, List<String>>, List<ConfigProperty>) - Method in class alluxio.worker.block.BlockMasterClient
Registers with the master in a stream.
registerWorker(RegisterWorkerPRequest, StreamObserver<RegisterWorkerPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
Registers a worker.
registerWorker(RegisterWorkerPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
Registers a worker.
registerWorker(RegisterWorkerPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
Registers a worker.
registerWorker(RegisterWorkerPRequest, StreamObserver<RegisterWorkerPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Registers a worker.
registerWorker(RegisterWorkerPRequest, StreamObserver<RegisterWorkerPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
registerWorker(WorkerNetAddress, BuildVersion) - Method in class alluxio.master.job.JobMaster
Returns a worker id for the given worker.
registerWorker(WorkerNetAddress) - Method in interface alluxio.worker.job.JobMasterClient
Returns a worker id for a workers net address.
registerWorker(WorkerNetAddress) - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
 
registerWorker(JobMasterClient, WorkerNetAddress) - Static method in class alluxio.worker.JobWorkerIdRegistry
Registers with JobMaster to get a new job worker id.
registerWorkerDeleteListener(Consumer<Address>) - Method in interface alluxio.master.block.BlockMaster
Registers callback functions to use when detecting lost workers.
registerWorkerDeleteListener(Consumer<Address>) - Method in class alluxio.master.block.DefaultBlockMaster
 
registerWorkerLostListener(Consumer<Address>) - Method in interface alluxio.master.block.BlockMaster
Registers callback functions to use when detecting lost workers.
registerWorkerLostListener(Consumer<Address>) - Method in class alluxio.master.block.DefaultBlockMaster
 
RegisterWorkerPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RegisterWorkerPOptions
RegisterWorkerPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RegisterWorkerPOptions
RegisterWorkerPOptionsOrBuilder - Interface in alluxio.grpc
 
RegisterWorkerPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RegisterWorkerPRequest
RegisterWorkerPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RegisterWorkerPRequest
RegisterWorkerPRequestOrBuilder - Interface in alluxio.grpc
 
RegisterWorkerPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RegisterWorkerPResponse
RegisterWorkerPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RegisterWorkerPResponse
RegisterWorkerPResponseOrBuilder - Interface in alluxio.grpc
 
registerWorkerStream(StreamObserver<RegisterWorkerPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
Registers a worker in a streaming way
registerWorkerStream(StreamObserver<RegisterWorkerPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Registers a worker in a streaming way
registerWorkerStream(StreamObserver<RegisterWorkerPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
Registry<T extends Server<U>,U> - Class in alluxio
Class for registering individual Servers that run within an Alluxio process.
Registry() - Constructor for class alluxio.Registry
Creates a new instance of Registry.
reinit(boolean) - Method in class alluxio.client.file.FileSystemContext
Closes the context, updates configuration from meta master, then re-initializes the context.
ReinitAllowerResource(CountingLatch) - Constructor for class alluxio.client.file.FileSystemContextReinitializer.ReinitAllowerResource
Waits the count to reach zero, then blocks further constructions of FileSystemContextReinitializer.ReinitBlockerResource until FileSystemContextReinitializer.ReinitAllowerResource.close().
ReinitBlockerResource(CountingLatch) - Constructor for class alluxio.client.file.FileSystemContextReinitializer.ReinitBlockerResource
Increases the count of the latch.
reinitialize() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Resets the internal bookkeeping state of this task, allowing a subsequent fork.
reinitialize() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
RejectingServer - Class in alluxio.network
A server which listens on a socket and closes all connections.
RejectingServer(InetSocketAddress) - Constructor for class alluxio.network.RejectingServer
 
RejectingServer(InetSocketAddress, long) - Constructor for class alluxio.network.RejectingServer
 
rejectUnsupportedResources() - Method in class alluxio.proxy.s3.S3Handler
Reject unsupported request from the given subresources from request.
rejectUnsupportedResources() - Method in class alluxio.worker.s3.S3NettyHandler
Reject unsupported request from the given subresources from request.
RelatedS3Operations - Annotation Type in alluxio.cli
An annotation for methods with related S3 operations.
release(long) - Method in interface alluxio.client.file.cache.store.PageStoreDir
Release the pre-reserved space.
release() - Method in class alluxio.concurrent.CountingLatch
Unblocks threads blocked on calling CountingLatch.inc().
release(String, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
release(String, FuseFileInfo) - Method in class alluxio.fuse.StackFS
 
release() - Method in class alluxio.grpc.ReadableDataBuffer
 
release(String, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
release() - Method in class alluxio.network.protocol.databuffer.CompositeDataBuffer
 
release() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Releases the underlying buffer of this DataBuffer if no longer needed.
release() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
release() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
Release the Netty ByteBuf.
release() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
release(ByteBuffer) - Static method in class alluxio.network.protocol.databuffer.NioDirectBufferPool
 
release(T) - Method in class alluxio.resource.DynamicResourcePool
Releases the resource to the pool.
release(T) - Method in interface alluxio.resource.Pool
Releases the resource to the pool.
release(T) - Method in class alluxio.resource.ResourcePool
Releases an object of type T, this must be called after the thread is done using a resource obtained by acquire.
release(ByteBuffer) - Method in class alluxio.underfs.ByteBufferResourcePool
 
release(InputStream) - Method in class alluxio.underfs.UfsInputStreamCache
Releases an input stream.
releaseCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
releaseConnection(GrpcChannelKey) - Method in class alluxio.grpc.GrpcChannelPool
Decreases the ref-count of the ManagedChannel for the given address.
releasedir(String, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
releaseInternal(String, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
releaseLock() - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
releaseLock() - Method in class alluxio.fuse.file.FuseFileInStream
 
releaseLock() - Method in class alluxio.fuse.file.FuseFileOutStream
 
releaseLock() - Method in interface alluxio.fuse.file.FuseFileStream
Releases the lock resource the stream obtained.
releaseLock() - Method in class alluxio.fuse.file.FusePositionReader
 
releaseLock() - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
releaseMasterClient(JobMasterClient) - Method in class alluxio.client.job.JobContext
Releases a job master client into the job master client pool.
releaseNettyChannel(WorkerNetAddress, Channel) - Method in class alluxio.client.file.FileSystemContext
Releases a netty channel to the channel pools.
releaseRegisterLease(long) - Method in interface alluxio.master.block.BlockMaster
Releases the RegisterLease for the specified worker.
releaseRegisterLease(long) - Method in class alluxio.master.block.DefaultBlockMaster
 
reloadProperties() - Static method in class alluxio.conf.Configuration
Reloads site properties from disk.
relogin() - Method in class alluxio.security.user.BaseUserState
 
relogin() - Method in interface alluxio.security.user.UserState
Attempts to log in again, and returns the new User.
remainContent() - Method in class alluxio.worker.s3.S3NettyHandler
 
remaining() - Method in interface alluxio.client.BoundedStream
 
remaining() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
remaining() - Method in class alluxio.client.file.PositionReadFileInStream
 
remaining() - Method in class alluxio.client.file.ufs.UfsFileInStream
 
remaining() - Method in class alluxio.file.ByteArrayTargetBuffer
 
remaining() - Method in class alluxio.file.ByteBufferTargetBuffer
 
remaining() - Method in class alluxio.file.NettyBufTargetBuffer
 
remaining() - Method in interface alluxio.file.ReadTargetBuffer
 
remaining() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
remainingCapacity() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
remove(Object) - Method in class alluxio.collections.ConcurrentHashSet
 
remove(Object, Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
remove(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
remove(Object) - Method in class alluxio.collections.DelegatingSet
 
remove(T) - Method in interface alluxio.collections.FieldIndex
Removes the object o from the index.
remove(Object) - Method in class alluxio.collections.IndexedSet
Removes an object from the set.
remove(T) - Method in class alluxio.collections.NonUniqueFieldIndex
 
remove(T) - Method in class alluxio.collections.UniqueFieldIndex
 
remove(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
remove(int) - Method in class alluxio.collections.UnmodifiableArrayList
 
remove(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Remove the value set for key.
remove(DeletePRequest, StreamObserver<DeletePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest, StreamObserver<DeletePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest, StreamObserver<DeletePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest, StreamObserver<DeletePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Deletes a file or a directory and returns whether the remove operation succeeded.
remove(DeletePRequest, StreamObserver<DeletePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
remove() - Method in class alluxio.master.file.meta.InodeTreeBufferedIterator
 
remove(InodeView) - Method in class alluxio.master.file.meta.TtlBucketList
Removes an inode from the bucket containing it if the inode is in one of the buckets, otherwise, do nothing.
remove(Supplier<JournalContext>, String, Set<String>) - Method in class alluxio.master.meta.PathProperties
Removes the specified set of keys from the properties for path.
remove(K) - Method in class alluxio.master.metastore.caching.Cache
Removes a key from the cache.
remove(Long) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
remove(Long) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
remove(Long) - Method in interface alluxio.master.metastore.InodeStore
Removes an inode from the inode store.
remove(InodeView) - Method in interface alluxio.master.metastore.InodeStore
Removes an inode from the inode store.
remove(Long) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
remove(Object) - Method in class alluxio.master.scheduler.Scheduler.BoundedPriorityBlockingQueue
 
remove() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Removes the User from the ThreadLocal variable.
remove(AlluxioURI) - Method in class alluxio.underfs.UfsStatusCache
Remove a status from the cache.
remove(Long) - Method in class alluxio.util.BucketCounter
remove a number to be counted.
remove(T) - Method in class alluxio.util.executor.ControllableQueue
Removes an element.
remove(String) - Method in class alluxio.worker.dora.DoraOpenFileHandleContainer
Remove a specified key.
remove(DeletePRequest, StreamObserver<DeletePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
REMOVE_ALL_VALUE - Static variable in enum alluxio.grpc.SetAclAction
REMOVE_ALL = 3;
REMOVE_ALL_VALUE - Static variable in enum alluxio.proto.journal.File.PSetAclAction
REMOVE_ALL = 3;
REMOVE_DEFAULT_VALUE - Static variable in enum alluxio.grpc.SetAclAction
REMOVE_DEFAULT = 4;
REMOVE_DEFAULT_VALUE - Static variable in enum alluxio.proto.journal.File.PSetAclAction
REMOVE_DEFAULT = 4;
REMOVE_PATH_PROPERTIES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
REMOVE_SYNC_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
REMOVE_VALUE - Static variable in enum alluxio.grpc.SetAclAction
REMOVE = 2;
REMOVE_VALUE - Static variable in enum alluxio.proto.journal.File.PSetAclAction
REMOVE = 2;
removeAcl(List<AclEntry>) - Method in class alluxio.master.file.meta.MutableInode
Removes ACL entries.
removeAddedBlocks(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
removeAddedBlocksOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of added blocks on all tiers (deprecated since 2.0, replaced by addedBlocks)
removeAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
removeAll(Collection<?>) - Method in class alluxio.collections.DelegatingSet
 
removeAll(Collection<?>) - Method in class alluxio.collections.UnmodifiableArrayList
 
removeAll(Supplier<JournalContext>, String) - Method in class alluxio.master.meta.PathProperties
Removes all properties for path.
removeBlock(RemoveBlockRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Removes a block from worker.
removeBlock(RemoveBlockRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
removeBlock(RemoveBlockRequest, StreamObserver<RemoveBlockResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
removeBlock(RemoveBlockRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
removeBlock(RemoveBlockRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
removeBlock(RemoveBlockRequest, StreamObserver<RemoveBlockResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
removeBlock(long) - Method in interface alluxio.master.metastore.BlockMetaStore
Removes a block, or does nothing if the block does not exist.
removeBlock(long) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
removeBlock(long) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
removeBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Removes an existing block.
removeBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Frees a block from Alluxio managed space.
removeBlockFromWorkerMeta(long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Removes a block from the worker.
removeBlockMeta(BlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Removes a block from this storage dir.
RemoveBlockRequest - Class in alluxio.grpc
next available id: 2
RemoveBlockRequest.Builder - Class in alluxio.grpc
next available id: 2
RemoveBlockRequestOrBuilder - Interface in alluxio.grpc
 
RemoveBlockResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RemoveBlockResponse
RemoveBlockResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RemoveBlockResponse
RemoveBlockResponseOrBuilder - Interface in alluxio.grpc
 
removeBlocks(int) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
removeBlocks(Collection<Long>, boolean) - Method in interface alluxio.master.block.BlockMaster
Removes blocks from workers.
removeBlocks(Collection<Long>, boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
removeBlockStatus(int) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
removeByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Removes the subset of objects with the specified index field value.
removeCandidates(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
removeCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
map<string, int64> capacityBytesOnTiers = 2;
removeCapacityBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> capacityBytesOnTiers = 2;
removeCapacityBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> capacityBytesOnTiers = 8;
removeChild(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Removes a child node from the node.
removeChild(long, String) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
removeChild(long, String) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
removeChild(long, String) - Method in interface alluxio.master.metastore.InodeStore
Removes a child from a parent inode.
removeChild(Long, String) - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
Adds an edge removal operation to the write batch.
removeChild(long, String) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
removeChildren(int) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
removeChildrenListener(String) - Method in class alluxio.membership.AlluxioEtcdClient
Remove state listener for children on a given parentPath.
removeClientMetrics(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
removeClusterConfigs(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
removeCols(int) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
removeColumn(String) - Method in class alluxio.grpc.table.FileStatistics.Builder
map column names to column statistics
removeColumnConstraints(String) - Method in class alluxio.grpc.table.Constraint.Builder
maps column to constraint, columns not present are not constrained
removeCommands(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
removeConfigs(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
removeConfigs(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
removeCurrentBlocks(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
removeCurrentBlocksOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of list of blocks on each tier (deprecated since 2.0, replaced by currentBlocks
removeDataCols(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
REMOVEDBLOCKIDS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
 
removeDisabledWorker(RemoveDisabledWorkerPOptions) - Method in interface alluxio.client.block.BlockMasterClient
Revert disabling a worker, enabling it to register to the cluster.
removeDisabledWorker(RemoveDisabledWorkerPOptions) - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
removeDisabledWorker(RemoveDisabledWorkerPOptions, StreamObserver<RemoveDisabledWorkerPResponse>) - Method in interface alluxio.grpc.BlockMasterClientServiceGrpc.AsyncService
If target worker is in the decommissioned worker set, return true, remove target worker from decommissioned worker set; else, return false.
removeDisabledWorker(RemoveDisabledWorkerPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
If target worker is in the decommissioned worker set, return true, remove target worker from decommissioned worker set; else, return false.
removeDisabledWorker(RemoveDisabledWorkerPOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
If target worker is in the decommissioned worker set, return true, remove target worker from decommissioned worker set; else, return false.
removeDisabledWorker(RemoveDisabledWorkerPOptions, StreamObserver<RemoveDisabledWorkerPResponse>) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
If target worker is in the decommissioned worker set, return true, remove target worker from decommissioned worker set; else, return false.
removeDisabledWorker(RemoveDisabledWorkerPOptions) - Method in interface alluxio.master.block.BlockMaster
Revert disabling a worker, enabling it to register to the cluster.
removeDisabledWorker(RemoveDisabledWorkerPOptions, StreamObserver<RemoveDisabledWorkerPResponse>) - Method in class alluxio.master.block.BlockMasterClientServiceHandler
 
removeDisabledWorker(RemoveDisabledWorkerPOptions) - Method in class alluxio.master.block.DefaultBlockMaster
 
RemoveDisabledWorkerPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RemoveDisabledWorkerPOptions
RemoveDisabledWorkerPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RemoveDisabledWorkerPOptions
RemoveDisabledWorkerPOptionsOrBuilder - Interface in alluxio.grpc
 
RemoveDisabledWorkerPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RemoveDisabledWorkerPResponse
RemoveDisabledWorkerPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RemoveDisabledWorkerPResponse
RemoveDisabledWorkerPResponseOrBuilder - Interface in alluxio.grpc
 
RemovedKey - Class in alluxio.conf
This class contains old PropertyKeys which have been removed from use This class is used to track keys which were deprecated in previous versions and subsequently removed in a future version.
removeDoraMeta(String) - Method in interface alluxio.worker.dora.DoraMetaStore
Removes a dora meta, or does nothing if the dora meta does not exist.
removeDoraMeta(String) - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
Removes the metadata from the RocksDB.
removeEntries(int) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
removeEntries(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
removeEntries(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
removeEntry(AclEntry) - Method in class alluxio.security.authorization.AccessControlList
Removes the specified entry.
removeEntry(AclEntry) - Method in class alluxio.security.authorization.DefaultAccessControlList
Removes the specified entry.
removeEntry(AclEntry) - Method in class alluxio.security.authorization.ExtendedACLEntries
Removes the specified entry.
removeErrors(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
removeErrors(String) - Method in class alluxio.grpc.PolicyStatus.Builder
map<string, string> errors = 10;
removeExtendedAcl() - Method in class alluxio.master.file.meta.MutableInode
Removes the extended ACL entries.
removeExtendedEntries() - Method in class alluxio.security.authorization.AccessControlList
Removes all of the exnteded entries.
removeFailures(int) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
removeFailures(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
removeFailures(int) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
removeFileBlockInfos(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
removeFileInfos(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
removeFileInfos(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
removeFromBackingStore(K) - Method in class alluxio.master.metastore.caching.Cache
Removes a key from the backing store.
removeFromMetaStore(String) - Method in class alluxio.worker.dora.DoraMetaManager
Removes meta of a file from the meta store.
removeGroupActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
removeHeartbeat(ClientContext) - Static method in class alluxio.client.metrics.MetricsHeartbeatContext
Removes an application from the metrics heartbeat.
removeIf(Predicate<? super T>) - Method in class alluxio.collections.DelegatingSet
 
removeInaccessibleStorage() - Method in interface alluxio.worker.block.BlockStore
Remove Storage directories that are no longer accessible.
removeInfo(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
removeInfos(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
removeInnerValue(K1, K2) - Method in class alluxio.collections.TwoKeyConcurrentMap
 
removeInode(InodeView) - Method in class alluxio.master.file.meta.TtlBucket
Removes an inode from the bucket.
removeInode(Long) - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
Adds an inode removal operation to the write batch.
removeInodeAndParentEdge(InodeView) - Method in interface alluxio.master.metastore.InodeStore
Removes an inode and the edge leading to it from the inode store.
removeJobInfos(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
removeJobMasterStatus(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
removeJobProgress(int) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
removeJobStatusBlock(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
removeJournalEntries(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
removeJournalSink(Master, JournalSink) - Method in class alluxio.master.journal.AbstractJournalSystem
 
removeJournalSink(Master, JournalSink) - Method in interface alluxio.master.journal.JournalSystem
 
removeJournalSink(Master, JournalSink) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
removeLastInode() - Method in class alluxio.master.file.meta.LockedInodePath
Removes the last inode from the list.
removeListenerInternal(String, AlluxioEtcdClient.WatchType) - Method in class alluxio.membership.AlluxioEtcdClient
Remove listener on given path.
removeLocation(long, long) - Method in interface alluxio.master.metastore.BlockMetaStore
Removes a block location.
removeLocation(long, long) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
removeLocation(long, long) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
removeLocations(int) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
removeLongestRunning(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
removeLostStorage(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of lost storage paths on all tiers
removeLostStorage(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of tier alias to a list of lost storage paths.
removeLostStorage(String) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
a map from tier alias to the lost storage paths
removeMasterAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
removeMasterVersions(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
removeMetrics(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
removeMetrics(int) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
removeMetrics(String) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
map<string, .alluxio.grpc.metric.MetricValue> metrics = 1;
removeMetrics(String) - Static method in class alluxio.metrics.MetricsSystem
Removes the metric with the given name.
removeMount(long) - Method in class alluxio.underfs.AbstractUfsManager
 
removeMount(long) - Method in class alluxio.underfs.MasterUfsManager
 
removeMount(long) - Method in interface alluxio.underfs.UfsManager
Removes the association from a mount id to a UFS instance.
removeMountPoints(String) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
map<string, .alluxio.grpc.file.MountPointInfo> mountPoints = 1;
removeOptions(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
map<string, string> options = 5;
removePage(PageId, boolean) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
removePage(PageId) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
removePage(PageId, boolean) - Method in interface alluxio.client.file.cache.PageMetaStore
Removes a page.
removePage(PageId) - Method in interface alluxio.client.file.cache.PageMetaStore
Removes a page.
removePage(PageId) - Method in class alluxio.client.file.cache.QuotaPageMetaStore
 
removeParameter(String) - Method in class alluxio.grpc.table.Database.Builder
map<string, string> parameter = 4;
removeParameters(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
map<string, string> parameters = 7;
removeParameters(String) - Method in class alluxio.grpc.table.TableInfo.Builder
map<string, string> parameters = 7;
removePartitionCols(int) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
removePartitions(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
removePartitionStatistics(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsList> partition_statistics = 1;
removePartsDirAndMPMetaFile(AlluxioURI) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
Cleanup the multipart upload temporary folder holding the parts files.
removePartsDirAndMPMetaFile(AlluxioURI) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
Cleanup the multipart upload temporary folder holding the parts files.
removePathConfigs(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
map<string, .alluxio.grpc.meta.ConfigProperties> pathConfigs = 2;
removePathConfiguration(AlluxioURI, Set<PropertyKey>) - Method in interface alluxio.client.meta.MetaMasterConfigClient
Removes properties for a path.
removePathConfiguration(AlluxioURI) - Method in interface alluxio.client.meta.MetaMasterConfigClient
Removes all properties for a path.
removePathConfiguration(AlluxioURI, Set<PropertyKey>) - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
removePathConfiguration(AlluxioURI) - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
removePathConfiguration(RemovePathConfigurationPRequest, StreamObserver<RemovePathConfigurationPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
Removes properties for a path, if the keys are empty, it means remove all properties.
removePathConfiguration(RemovePathConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
Removes properties for a path, if the keys are empty, it means remove all properties.
removePathConfiguration(RemovePathConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
Removes properties for a path, if the keys are empty, it means remove all properties.
removePathConfiguration(RemovePathConfigurationPRequest, StreamObserver<RemovePathConfigurationPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
Removes properties for a path, if the keys are empty, it means remove all properties.
removePathConfiguration(String, Set<String>) - Method in class alluxio.master.meta.DefaultMetaMaster
 
removePathConfiguration(String) - Method in class alluxio.master.meta.DefaultMetaMaster
 
removePathConfiguration(String, Set<String>) - Method in interface alluxio.master.meta.MetaMaster
Removes properties for a path.
removePathConfiguration(String) - Method in interface alluxio.master.meta.MetaMaster
Removes all properties for a path.
removePathConfiguration(RemovePathConfigurationPRequest, StreamObserver<RemovePathConfigurationPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
 
RemovePathConfigurationPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RemovePathConfigurationPOptions
RemovePathConfigurationPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RemovePathConfigurationPOptions
RemovePathConfigurationPOptionsOrBuilder - Interface in alluxio.grpc
 
RemovePathConfigurationPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RemovePathConfigurationPRequest
RemovePathConfigurationPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RemovePathConfigurationPRequest
RemovePathConfigurationPRequestOrBuilder - Interface in alluxio.grpc
 
RemovePathConfigurationPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RemovePathConfigurationPResponse
RemovePathConfigurationPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.RemovePathConfigurationPResponse
RemovePathConfigurationPResponseOrBuilder - Interface in alluxio.grpc
 
removePersistFiles(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
removePolicy(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
removePolicy(RemovePolicyPRequest, StreamObserver<RemovePolicyPResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
Removes a policy definition
removePolicy(RemovePolicyPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
Removes a policy definition
removePolicy(RemovePolicyPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
Removes a policy definition
removePolicy(RemovePolicyPRequest, StreamObserver<RemovePolicyPResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
Removes a policy definition
RemovePolicyPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.RemovePolicyPOptions
RemovePolicyPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.RemovePolicyPOptions
RemovePolicyPOptionsOrBuilder - Interface in alluxio.grpc
 
RemovePolicyPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.RemovePolicyPRequest
RemovePolicyPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.RemovePolicyPRequest
RemovePolicyPRequestOrBuilder - Interface in alluxio.grpc
 
RemovePolicyPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.RemovePolicyPResponse
RemovePolicyPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.RemovePolicyPResponse
RemovePolicyPResponseOrBuilder - Interface in alluxio.grpc
 
removeProperties(int) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
removeProperties(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
removeProperties(String) - Method in class alluxio.grpc.MountPointInfo.Builder
map<string, string> properties = 6;
removeProperties(String) - Method in class alluxio.grpc.MountPOptions.Builder
map<string, string> properties = 2;
removeProperties(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
map<string, string> properties = 2;
removeProperties(String) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
map<string, string> properties = 1;
removeProperties(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
removeProperties(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
map<string, string> properties = 2;
removeProxyStatuses(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
removeQuorumServer(NetAddress) - Method in interface alluxio.client.journal.JournalMasterClient
Removes a server from journal quorum.
removeQuorumServer(NetAddress) - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
removeQuorumServer(RemoveQuorumServerPRequest, StreamObserver<RemoveQuorumServerPResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
Removes a server from embedded journal quorum.
removeQuorumServer(RemoveQuorumServerPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
Removes a server from embedded journal quorum.
removeQuorumServer(RemoveQuorumServerPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
Removes a server from embedded journal quorum.
removeQuorumServer(RemoveQuorumServerPRequest, StreamObserver<RemoveQuorumServerPResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
Removes a server from embedded journal quorum.
removeQuorumServer(NetAddress) - Method in class alluxio.master.journal.DefaultJournalMaster
 
removeQuorumServer(NetAddress) - Method in interface alluxio.master.journal.JournalMaster
Removes a server from journal quorum.
removeQuorumServer(RemoveQuorumServerPRequest, StreamObserver<RemoveQuorumServerPResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
 
removeQuorumServer(NetAddress) - Method in class alluxio.master.journal.raft.RaftJournalSystem
Removes from RAFT quorum, a server with given address.
RemoveQuorumServerPOptions - Class in alluxio.grpc
RemoveQuorumServer API
RemoveQuorumServerPOptions.Builder - Class in alluxio.grpc
RemoveQuorumServer API
RemoveQuorumServerPOptionsOrBuilder - Interface in alluxio.grpc
 
RemoveQuorumServerPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.RemoveQuorumServerPRequest
RemoveQuorumServerPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.RemoveQuorumServerPRequest
RemoveQuorumServerPRequestOrBuilder - Interface in alluxio.grpc
 
RemoveQuorumServerPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.RemoveQuorumServerPResponse
RemoveQuorumServerPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.RemoveQuorumServerPResponse
RemoveQuorumServerPResponseOrBuilder - Interface in alluxio.grpc
 
removeRanges(int) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
removeRecentActivities(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
removeRecentFailures(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
removeRoutes(int) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
removeRoutes(int) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
removeSerdelibParameters(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
map<string, string> serdelib_parameters = 4;
removeSerdeParameters(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
map<string, string> serde_parameters = 5;
removeServerInfo(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
removeSession(long) - Method in class alluxio.Sessions
Removes the given session from the session pool.
removeSortedBy(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
removeStateListener(String) - Method in class alluxio.membership.AlluxioEtcdClient
Remove state listener for give path.
removeStatistics(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
removeStatistics(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
removeStats(String) - Method in class alluxio.grpc.table.Layout.Builder
map<string, .alluxio.grpc.table.ColumnStatisticsInfo> stats = 4;
removeStatus(String) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
map<string, bool> status = 1;
removeStorageDir(StorageDir) - Method in interface alluxio.worker.block.meta.StorageTier
Removes a directory.
removeSummaryPerStatus(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
removeTablesErrors(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
map<string, string> tables_errors = 1;
removeTags(String) - Method in class alluxio.grpc.Metric.Builder
map<string, string> tags = 6;
removeTaskInfos(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
removeTempBlockMeta(TempBlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Removes a temp block from this storage dir.
removeTimer(ScheduledTimer) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Removes a timer from the scheduler.
removeTotalBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of total bytes on each tier
removeTransformations(int) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
removeUfsLocations(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
removeUfsStatus(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
removeUnused0(int) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
removeUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the map of space used in bytes on all tiers
removeUsedBytesOnTiers(String) - Method in class alluxio.grpc.BlockMasterInfo.Builder
map<string, int64> usedBytesOnTiers = 7;
removeUsedBytesOnTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the map of used bytes on each tier
removeUsedBytesOnTiers(String) - Method in class alluxio.grpc.WorkerInfo.Builder
map<string, int64> usedBytesOnTiers = 9;
removeUserActions(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
removeValues(String) - Method in class alluxio.grpc.InconsistentProperty.Builder
map<string, .alluxio.grpc.meta.InconsistentPropertyValues> values = 2;
removeWarns(String) - Method in class alluxio.grpc.ConfigCheckReport.Builder
Scope name as key
removeWorkerAddresses(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
removeWorkerHealths(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
removeWorkerInfos(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
removeWorkerLostStorageInfo(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
removeXattr(String) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
map<string, bytes> xattr = 6;
removeXattr(String) - Method in class alluxio.grpc.CreateFilePOptions.Builder
map<string, bytes> xattr = 11;
removeXattr(String) - Method in class alluxio.grpc.FileInfo.Builder
map<string, bytes> xattr = 32;
removeXattr(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
map<string, bytes> xattr = 11;
removeXattr(String) - Method in class alluxio.grpc.UfsStatus.Builder
map<string, bytes> xattr = 7;
removeXAttr(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
map<string, bytes> xAttr = 19;
removeXAttr(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
map<string, bytes> xAttr = 28;
removeXAttr(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
map<string, bytes> xAttr = 17;
removeXAttr(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Extended attributes, general purpose.
removexattrCallback(String, String) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
rename(RenamePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Rename the src to dst.
rename(RenamePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
rename(String, String, RenamePOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Rename a src file/dir to dst file/dir.
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
rename(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.rename(AlluxioURI, AlluxioURI, RenamePOptions) with default options.
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in interface alluxio.client.file.FileSystem
Renames an existing Alluxio path to another Alluxio path in Alluxio.
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
rename(AlluxioURI, AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Renames a file or a directory.
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Renames a file or a directory.
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.MetadataCachingFileSystem
 
rename(AlluxioURI, AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
rename(AlluxioURI, AlluxioURI, RenamePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
rename(String, String, int) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
rename(String, String, int) - Method in class alluxio.fuse.StackFS
 
rename(RenamePRequest, StreamObserver<RenamePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Renames a file or a directory.
rename(RenamePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Renames a file or a directory.
rename(RenamePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Renames a file or a directory.
rename(RenamePRequest, StreamObserver<RenamePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Renames a file or a directory.
rename(RenamePRequest, StreamObserver<RenamePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Renames a file or a directory.
rename(RenamePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Renames a file or a directory.
rename(RenamePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Renames a file or a directory.
rename(RenamePRequest, StreamObserver<RenamePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Renames a file or a directory.
rename(Path, Path) - Method in class alluxio.hadoop.AbstractFileSystem
 
rename(Path, Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
rename(String, String, int) - Method in interface alluxio.jnifuse.FuseFileSystem
 
Rename - Class in alluxio.master.backcompat.ops
Test for renaming a file.
Rename() - Constructor for class alluxio.master.backcompat.ops.Rename
 
rename(AlluxioURI, AlluxioURI, RenameContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
rename(AlluxioURI, AlluxioURI, RenameContext) - Method in interface alluxio.master.file.FileSystemMaster
Renames a file to a destination.
rename(RenamePRequest, StreamObserver<RenamePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
rename(Supplier<JournalContext>, File.RenameEntry) - Method in class alluxio.master.file.meta.InodeTree
 
RENAME - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
rename(String, String, RenamePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
rename(String, String, RenamePOptions) - Method in interface alluxio.worker.dora.DoraWorker
Rename src to dst.
rename(String, String, RenamePOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
 
rename(RenamePRequest, StreamObserver<RenamePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
RENAME_EXCHANGE - Static variable in class alluxio.fuse.AlluxioJniRenameUtils
 
RENAME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
RENAME_NOREPLACE - Static variable in class alluxio.fuse.AlluxioJniRenameUtils
 
RenameBuffer(ObjectUnderFileSystem.DeleteBuffer) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
Construct a new ObjectUnderFileSystem.RenameBuffer instance.
renameCallback(String, String) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
renameCallback(String, String, int) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
RenameContext - Class in alluxio.master.file.contexts
Used to merge and wrap RenamePOptions.
renameDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
renameDefaults(AlluxioConfiguration, boolean) - Static method in class alluxio.util.FileSystemOptionsUtils
 
renameDirectory(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameDirectory(String, String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
renameDirectory(String, String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
renameDirectory(String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
renameDirectory(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameDirectory(String, String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
renameDirectory(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a directory from src to dst in under file system.
renameDirectory(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameDirectoryDeepTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for renaming deep directory.
renameDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for renaming directory.
renameFile(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameFile(String, String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
renameFile(String, String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
renameFile(String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
renameFile(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameFile(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a file from src to dst in under file system.
renameFile(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for renaming file.
renameLargeDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for renaming large directory.
RenamePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.RenamePOptions
RenamePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.RenamePOptions
RenamePOptionsOrBuilder - Interface in alluxio.grpc
 
RenamePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.RenamePRequest
RenamePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.RenamePRequest
RenamePRequestOrBuilder - Interface in alluxio.grpc
 
RenamePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.RenamePResponse
RenamePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.RenamePResponse
RenamePResponseOrBuilder - Interface in alluxio.grpc
 
renameRenamableDirectory(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameRenamableDirectory(String, String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
renameRenamableDirectory(String, String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
renameRenamableDirectory(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameRenamableDirectory(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a directory from src to dst in under file system.
renameRenamableDirectory(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameRenamableDirectoryTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for renaming renamable directory.
renameRenamableFile(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameRenamableFile(String, String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
renameRenamableFile(String, String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
renameRenamableFile(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameRenamableFile(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a file from src to dst in under file system.
renameRenamableFile(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameRenamableFileTest() - Method in class alluxio.cli.UnderFileSystemCommonOperations
Test for renaming renamable file.
replace(K, V, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
replace(K, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
REPLACE_VALUE - Static variable in enum alluxio.grpc.SetAclAction
REPLACE = 0;
REPLACE_VALUE - Static variable in enum alluxio.proto.journal.File.PSetAclAction
REPLACE = 0;
replaceAcl(List<AclEntry>) - Method in class alluxio.master.file.meta.MutableInode
Replaces all existing ACL entries with a new list of entries.
REPLICATION_DURABLE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
REPLICATION_DURABLE_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
REPLICATION_MAX_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
REPLICATION_MAX_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
REPLICATION_MAX_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
REPLICATION_MAX_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
REPLICATION_MAX_INFINITY - Static variable in class alluxio.Constants
 
REPLICATION_MIN_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
REPLICATION_MIN_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
REPLICATION_MIN_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
REPLICATION_MIN_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
REPLICATIONDURABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
ReplicationLimitedFileIds - Class in alluxio.master.file.meta
Keeps track of which files have limited replication factors.
ReplicationLimitedFileIds() - Constructor for class alluxio.master.file.meta.ReplicationLimitedFileIds
 
REPLICATIONMAX_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
REPLICATIONMAX_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
REPLICATIONMAX_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
REPLICATIONMIN_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
REPLICATIONMIN_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
REPLICATIONMIN_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
report() - Method in class alluxio.metrics.sink.ConsoleSink
 
report() - Method in class alluxio.metrics.sink.CsvSink
 
report() - Method in class alluxio.metrics.sink.GraphiteSink
 
report() - Method in class alluxio.metrics.sink.JmxSink
 
report() - Method in class alluxio.metrics.sink.MetricsServlet
 
report() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
 
report() - Method in interface alluxio.metrics.sink.Sink
Reports the current values of all metrics.
report() - Method in class alluxio.metrics.sink.Slf4jSink
 
REPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.GetConfigReportPResponse
 
reportClientMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
ReportCommand - Class in alluxio.cli.fsadmin.command
Reports Alluxio running cluster information.
ReportCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.ReportCommand
 
reportLostBlocks(List<Long>) - Method in interface alluxio.master.block.BlockMaster
Reports the ids of the blocks lost on workers.
reportLostBlocks(List<Long>) - Method in class alluxio.master.block.DefaultBlockMaster
 
reportTracedLeak(String, String) - Method in class alluxio.resource.AlluxioResourceLeakDetector
A traced leak report which includes records of the recent accesses of the particular object and the stacktrace of where the particular object was created.
reportUntracedLeak(String) - Method in class alluxio.resource.AlluxioResourceLeakDetector
An untraced leak report where there is no information about recent object accesses nor where the stacktrace of where the object was created.
reportWorkerMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
request(int) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
REQUEST_BODY_FIELD_NUMBER - Static variable in class alluxio.grpc.SubmitJobPRequest
 
REQUESTHEADER_FIELD_NUMBER - Static variable in class alluxio.grpc.TransportMessage
 
REQUESTID_FIELD_NUMBER - Static variable in class alluxio.grpc.MessagingRequestHeader
 
REQUESTID_FIELD_NUMBER - Static variable in class alluxio.grpc.MessagingResponseHeader
 
requestLatestSnapshotData(SnapshotMetadata, StreamObserver<SnapshotData>) - Method in interface alluxio.grpc.RaftJournalServiceGrpc.AsyncService
Request to download the snapshot information from a particular machine.
requestLatestSnapshotData(SnapshotMetadata) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceBlockingStub
Request to download the snapshot information from a particular machine.
requestLatestSnapshotData(SnapshotMetadata, StreamObserver<SnapshotData>) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceStub
Request to download the snapshot information from a particular machine.
requestLatestSnapshotData(SnapshotMetadata) - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
Receive snapshot data from specified follower.
requestLatestSnapshotData(SnapshotMetadata, StreamObserver<SnapshotData>) - Method in class alluxio.master.journal.raft.RaftJournalServiceHandler
 
requestLatestSnapshotInfo(LatestSnapshotInfoPRequest, StreamObserver<SnapshotMetadata>) - Method in interface alluxio.grpc.RaftJournalServiceGrpc.AsyncService
Requests information about snapshots on a particular machine.
requestLatestSnapshotInfo(LatestSnapshotInfoPRequest) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceBlockingStub
Requests information about snapshots on a particular machine.
requestLatestSnapshotInfo(LatestSnapshotInfoPRequest) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceFutureStub
Requests information about snapshots on a particular machine.
requestLatestSnapshotInfo(LatestSnapshotInfoPRequest, StreamObserver<SnapshotMetadata>) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceStub
Requests information about snapshots on a particular machine.
requestLatestSnapshotInfo() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
 
requestLatestSnapshotInfo(LatestSnapshotInfoPRequest, StreamObserver<SnapshotMetadata>) - Method in class alluxio.master.journal.raft.RaftJournalServiceHandler
 
RequestLoggingFilter - Class in alluxio.proxy.s3.logging
Helper class for adding logs to request methods for debugging purposes.
RequestLoggingFilter() - Constructor for class alluxio.proxy.s3.logging.RequestLoggingFilter
 
requestRegisterLease(GetRegisterLeasePRequest, StreamObserver<GetRegisterLeasePResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
Requests a lease for registration
requestRegisterLease(GetRegisterLeasePRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
Requests a lease for registration
requestRegisterLease(GetRegisterLeasePRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
Requests a lease for registration
requestRegisterLease(GetRegisterLeasePRequest, StreamObserver<GetRegisterLeasePResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Requests a lease for registration
requestRegisterLease(GetRegisterLeasePRequest, StreamObserver<GetRegisterLeasePResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
requestSpace(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Requests to increase the size of a temp block.
requestSpace(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Request an amount of space for a block in its storage directory.
RequestType - Enum in alluxio.grpc
The read/write request type.
reserve(long) - Method in interface alluxio.client.file.cache.store.PageStoreDir
 
reset() - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
reset() - Method in interface alluxio.client.file.cache.evictor.CacheEvictor
Resets the evictor.
reset() - Method in class alluxio.client.file.cache.evictor.FIFOCacheEvictor
 
reset() - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
reset() - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
reset() - Method in class alluxio.client.file.cache.evictor.TwoChoiceRandomEvictor
 
reset() - Method in class alluxio.client.file.cache.evictor.UnevictableCacheEvictor
 
reset() - Method in interface alluxio.client.file.cache.PageMetaStore
Resets the meta store.
reset() - Method in class alluxio.client.file.cache.QuotaPageMetaStore
 
reset() - Method in class alluxio.client.file.cache.store.LocalPageStoreDir
Reset page store.
reset() - Method in class alluxio.client.file.cache.store.MemoryPageStore
 
reset() - Method in class alluxio.client.file.cache.store.MemoryPageStoreDir
 
reset() - Method in interface alluxio.client.file.cache.store.PageStoreDir
Reset page store.
reset() - Method in class alluxio.extensions.ExtensionFactoryRegistry
Resets the registry to its default state
reset() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
reset() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Resets the cluster to original state.
reset() - Method in class alluxio.master.backup.BackupTracker
Resets this tracker.
reset() - Method in class alluxio.master.file.meta.MutableInodeFile
Resets the file inode.
reset() - Method in class alluxio.master.meta.checkconf.ConfigurationStore
Resets the default ConfigurationStore.
reset() - Method in class alluxio.metrics.InstrumentedExecutorService
Resets the metrics monitored about the executor service.
reset() - Method in class alluxio.retry.CountingRetry
Reset the count of retries.
reset() - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Resets the registry to its default state
resetAllMetrics() - Static method in class alluxio.metrics.MetricsSystem
Resets all the metrics in the MetricsSystem.
resetClientPools() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Resets the client pools to the original state.
resetCountersAndGauges() - Static method in class alluxio.metrics.MetricsSystem
Resets all counters to 0 and unregisters gauges for testing.
resetMetaMasterConfigClient(MasterClientContext) - Method in class alluxio.client.file.ConfigHashSync
Resets the internal meta master client based on the new configuration.
resetPrimaryMasterAddressCache() - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
resetPrimaryMasterAddressCache() - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
Resets the cached primary master address.
resetPriorities() - Method in interface alluxio.client.journal.JournalMasterClient
Resets RaftPeer priorities.
resetPriorities() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
resetPriorities(ResetPrioritiesPRequest, StreamObserver<ResetPrioritiesPResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
Reset all the RaftPeer priorities.
resetPriorities(ResetPrioritiesPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
Reset all the RaftPeer priorities.
resetPriorities(ResetPrioritiesPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
Reset all the RaftPeer priorities.
resetPriorities(ResetPrioritiesPRequest, StreamObserver<ResetPrioritiesPResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
Reset all the RaftPeer priorities.
resetPriorities() - Method in class alluxio.master.journal.DefaultJournalMaster
 
resetPriorities() - Method in interface alluxio.master.journal.JournalMaster
Resets RaftPeer priorities.
resetPriorities(ResetPrioritiesPRequest, StreamObserver<ResetPrioritiesPResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
 
resetPriorities() - Method in class alluxio.master.journal.raft.RaftJournalSystem
Resets RaftPeer priorities.
ResetPrioritiesPOptions - Class in alluxio.grpc
ResetPriorities API
ResetPrioritiesPOptions.Builder - Class in alluxio.grpc
ResetPriorities API
ResetPrioritiesPOptionsOrBuilder - Interface in alluxio.grpc
 
ResetPrioritiesPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.ResetPrioritiesPRequest
ResetPrioritiesPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.ResetPrioritiesPRequest
ResetPrioritiesPRequestOrBuilder - Interface in alluxio.grpc
 
ResetPrioritiesPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.ResetPrioritiesPResponse
ResetPrioritiesPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.ResetPrioritiesPResponse
ResetPrioritiesPResponseOrBuilder - Interface in alluxio.grpc
 
resetState() - Method in class alluxio.master.block.DefaultBlockMaster
 
resetState() - Method in class alluxio.master.file.meta.InodeDirectoryIdGenerator
 
resetState() - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
resetState() - Method in class alluxio.master.file.meta.MountTable.State
 
resetState() - Method in interface alluxio.master.journal.DelegatingJournaled
 
resetState() - Method in interface alluxio.master.journal.Journaled
Resets the object's journaled state.
resetState() - Method in class alluxio.master.journal.JournaledGroup
 
resetState() - Method in interface alluxio.master.journal.NoopJournaled
 
resetState() - Method in class alluxio.master.journal.SingleEntryJournaled
 
resetState() - Method in class alluxio.master.meta.DefaultMetaMaster
 
resetState() - Method in class alluxio.master.meta.DefaultMetaMaster.State
 
resetState() - Method in class alluxio.master.meta.PathProperties.State
 
resetState() - Method in class alluxio.master.scheduler.JournaledJobMetaStore
 
resizeTempBlockMeta(TempBlockMeta, long) - Method in interface alluxio.worker.block.meta.StorageDir
Changes the size of a temp block.
resolve(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Resolves the given Alluxio path.
resolveHostName(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Resolves a given hostname by a canonical hostname.
resolveIpAddress(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Resolves a given hostname IP address.
resolveUri(AlluxioURI, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
resolveUri(AlluxioURI, String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
resolveUri(AlluxioURI, String) - Method in interface alluxio.underfs.UnderFileSystem
Returns an AlluxioURI representation for the UnderFileSystem given a base UFS URI, and the Alluxio path from the base.
resolveUri(AlluxioURI, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
RESOURCE_EXHAUSTED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
ResourceExhausted indicates some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
ResourceExhaustedException - Exception in alluxio.exception.status
Exception indicating that some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
ResourceExhaustedException(String) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedException(Throwable) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedException(String, Throwable) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that some resource has been exhausted, perhaps a per-user quota, or perhaps the task queue.
ResourceExhaustedRuntimeException(String, boolean) - Constructor for exception alluxio.exception.runtime.ResourceExhaustedRuntimeException
Constructor.
ResourceExhaustedRuntimeException(String, Throwable, boolean) - Constructor for exception alluxio.exception.runtime.ResourceExhaustedRuntimeException
Constructor.
ResourceInternal(R) - Constructor for class alluxio.resource.DynamicResourcePool.ResourceInternal
ResourcePool<T> - Class in alluxio.resource
Class representing a pool of resources to be temporarily used and returned.
ResourcePool(int) - Constructor for class alluxio.resource.ResourcePool
Creates a ResourcePool instance with the specified capacity.
ResourcePool(int, ConcurrentLinkedQueue<T>) - Constructor for class alluxio.resource.ResourcePool
Internal constructor that can provide an object to be used for the internal queue.
ResponseEvent - Interface in alluxio.client.file.dora.netty.event
Response event.
ResponseEventContext - Class in alluxio.client.file.dora.netty.event
Response event context is used for recording the following information.
ResponseEventContext(NettyDataReaderStateMachine) - Constructor for class alluxio.client.file.dora.netty.event.ResponseEventContext
Response event context is used for recording the following information.
ResponseEventFactory - Class in alluxio.client.file.dora.netty.event
Response Event Factory.
ResponseFileInfo - Class in alluxio.worker.http
A POJO for providing File Information HTTP Response.
ResponseFileInfo(String, String, long) - Constructor for class alluxio.worker.http.ResponseFileInfo
A POJO for providing File Information HTTP Response.
RESPONSEHEADER_FIELD_NUMBER - Static variable in class alluxio.grpc.TransportMessage
 
REST_API_PREFIX - Static variable in class alluxio.Constants
 
restartMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Restarts the master(s).
restartWorker() - Method in class alluxio.master.LocalAlluxioJobCluster
Stops the current worker and starts a new one.
restartWorkers(Collection<WorkerNetAddress>) - Method in class alluxio.master.AbstractLocalAlluxioCluster
Restarts workers with the addresses provided, so that the workers can restart with static addresses to simulate a worker restart in the cluster.
restartZk() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Restarts the cluster's Zookeeper service.
restartZk() - Method in class alluxio.multi.process.MultiProcessCluster
Restarts the Zookeeper cluster.
restoreFromCheckpoint(File, ExecutorService) - Method in class alluxio.master.block.DefaultBlockMaster
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.file.meta.CheckpointedIdHashSet
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.file.meta.InodeCounter
 
restoreFromCheckpoint(File, ExecutorService) - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.file.meta.TtlBucketList
 
restoreFromCheckpoint(File, ExecutorService) - Method in interface alluxio.master.journal.checkpoint.Checkpointed
Restores state from a checkpoint asynchronously.
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.master.journal.checkpoint.Checkpointed
Restores state from a checkpoint.
restoreFromCheckpoint(File, ExecutorService) - Method in interface alluxio.master.journal.DelegatingJournaled
 
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.master.journal.DelegatingJournaled
 
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.master.journal.Journaled
 
restoreFromCheckpoint(File, ExecutorService) - Method in class alluxio.master.journal.JournaledGroup
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.journal.JournaledGroup
 
restoreFromCheckpoint(CheckpointInputStream, List<? extends Checkpointed>) - Static method in class alluxio.master.journal.JournalUtils
Restores the given checkpointed components from a composite checkpoint.
restoreFromCheckpoint(File, ExecutorService) - Method in interface alluxio.master.journal.NoopJournaled
 
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.master.journal.NoopJournaled
 
restoreFromCheckpoint(File, ExecutorService) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
restoreFromCheckpoint(File, ExecutorService) - Method in interface alluxio.rocks.RocksCheckpointed
 
restoreFromCheckpoint(CheckpointInputStream) - Method in interface alluxio.rocks.RocksCheckpointed
 
restoreFromCheckpoint(File) - Method in class alluxio.rocks.RocksStore
Restores RocksDB state from a checkpoint at the provided location.
restoreFromCheckpoint(CheckpointInputStream) - Method in class alluxio.rocks.RocksStore
Restores the database from a checkpoint.
restoreJournalEntryCheckpoint(CheckpointInputStream, Journaled) - Static method in class alluxio.master.journal.JournalUtils
Restores the given journaled object from the journal entries in the input stream.
restoreTaskUpdates(List<TaskInfo>) - Method in class alluxio.worker.job.task.TaskExecutorManager
Adds the given tasks to the task updates data structure.
RestUtils - Class in alluxio
Utilities for handling REST calls.
RestUtils.ErrorResponse - Class in alluxio
Error response when RestUtils.RestCallable.call() throws an exception.
RestUtils.RestCallable<T> - Interface in alluxio
An interface representing a callable.
RESULT_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
ResultStream<T> - Interface in alluxio.master.file
Used to receive stream of items.
resume() - Method in interface alluxio.master.journal.JournalSystem
Resumes applying for all journals.
resume() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
resume() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
Resumes the applier.
resume() - Method in class alluxio.master.journal.raft.JournalStateMachine
Resumes applying to masters.
resume() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
resume() - Method in class alluxio.master.journal.ufs.UfsJournal
Resumes the journal.
resume() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
resume() - Method in class alluxio.worker.job.task.PausableThreadPoolExecutor
Resume all threads to run new tasks.
retainAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
retainAll(Collection<?>) - Method in class alluxio.collections.DelegatingSet
 
retainAll(Collection<?>) - Method in class alluxio.collections.UnmodifiableArrayList
 
retry(String, RetryUtils.RunnableThrowsIOException, RetryPolicy) - Static method in class alluxio.retry.RetryUtils
Retries the given method until it doesn't throw an IO exception or the retry policy expires.
RETRY_TIMES - Static variable in class alluxio.membership.AlluxioEtcdClient
 
RETRYABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockStatus
 
RETRYABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileFailure
 
RETRYABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileFailure
 
RETRYABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.RouteFailure
 
retryCallable(String, Callable<V>, RetryPolicy) - Static method in class alluxio.retry.RetryUtils
Notice we assume the exception with the method is retryable, so we are not wasting time here.
RetryHandlingBlockMasterClient - Class in alluxio.client.block
A wrapper for the gRPC client to interact with the block master, used by alluxio clients.
RetryHandlingBlockMasterClient(MasterClientContext) - Constructor for class alluxio.client.block.RetryHandlingBlockMasterClient
Creates a new block master client.
RetryHandlingBlockMasterClient(MasterClientContext, InetSocketAddress) - Constructor for class alluxio.client.block.RetryHandlingBlockMasterClient
Creates a new block master client.
RetryHandlingBlockMasterClient(MasterClientContext, InetSocketAddress, Supplier<RetryPolicy>) - Constructor for class alluxio.client.block.RetryHandlingBlockMasterClient
Creates a new block master client.
RetryHandlingFileSystemMasterClient - Class in alluxio.client.file
A wrapper for the gRPC client to interact with the file system master, used by alluxio clients.
RetryHandlingFileSystemMasterClient(MasterClientContext) - Constructor for class alluxio.client.file.RetryHandlingFileSystemMasterClient
Creates a new RetryHandlingFileSystemMasterClient instance.
RetryHandlingJobMasterClient - Class in alluxio.client.job
A wrapper for the gRPC client to interact with the job service master, used by job service clients.
RetryHandlingJobMasterClient(JobMasterClientContext) - Constructor for class alluxio.client.job.RetryHandlingJobMasterClient
Creates a new job master client.
RetryHandlingJobMasterClient - Class in alluxio.worker.job
A wrapper for the gRPC client to interact with the job service master, used by job service workers.
RetryHandlingJobMasterClient(JobMasterClientContext) - Constructor for class alluxio.worker.job.RetryHandlingJobMasterClient
Creates a new job master client.
RetryHandlingJobMasterMasterClient - Class in alluxio.master.meta
A wrapper for the gRPC client to interact with the primary job master, used by Alluxio standby job masters.
RetryHandlingJobMasterMasterClient(JobMasterClientContext) - Constructor for class alluxio.master.meta.RetryHandlingJobMasterMasterClient
Creates a instance of RetryHandlingJobMasterMasterClient.
RetryHandlingJournalMasterClient - Class in alluxio.client.journal
A wrapper for the gRPC client to interact with the journal master, used by alluxio clients.
RetryHandlingJournalMasterClient(MasterClientContext) - Constructor for class alluxio.client.journal.RetryHandlingJournalMasterClient
Creates a new journal master client.
RetryHandlingMetaMasterClient - Class in alluxio.client.meta
A wrapper for the gRPC client to interact with the meta master.
RetryHandlingMetaMasterClient(MasterClientContext) - Constructor for class alluxio.client.meta.RetryHandlingMetaMasterClient
Creates a new meta master client.
RetryHandlingMetaMasterConfigClient - Class in alluxio.client.meta
A wrapper for the gRPC client to interact with the meta master.
RetryHandlingMetaMasterConfigClient(MasterClientContext) - Constructor for class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
Creates a new meta master client.
RetryHandlingMetaMasterMasterClient - Class in alluxio.master.meta
A wrapper for the gRPC client to interact with the primary meta master, used by Alluxio standby masters.
RetryHandlingMetaMasterMasterClient(MasterClientContext) - Constructor for class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
RetryHandlingMetaMasterProxyClient - Class in alluxio.proxy
A wrapper for the gRPC client to interact with the meta master.
RetryHandlingMetaMasterProxyClient(Address, MasterClientContext, long) - Constructor for class alluxio.proxy.RetryHandlingMetaMasterProxyClient
Creates a new meta master client.
RetryHandlingMetricsMasterClient - Class in alluxio.client.metrics
A wrapper for the gRPC client to interact with the metrics master.
RetryHandlingMetricsMasterClient(MasterClientContext) - Constructor for class alluxio.client.metrics.RetryHandlingMetricsMasterClient
Creates a new metrics master client.
RetryHandlingTableMasterClient - Class in alluxio.client.table
A wrapper for the gRPC client to interact with the table master.
RetryHandlingTableMasterClient(MasterClientContext) - Constructor for class alluxio.client.table.RetryHandlingTableMasterClient
Creates a new block master client.
RetryInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.RetryInfo
RetryInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.RetryInfo
RetryInfoOrBuilder - Interface in alluxio.grpc
 
retryOnException(ObjectUnderFileSystem.ObjectStoreOperation<T>, Supplier<String>) - Method in class alluxio.underfs.ObjectUnderFileSystem
Retries the given object store operation when it throws exceptions to resolve eventual consistency issue.
RetryPolicy - Interface in alluxio.retry
Policy for determining whether retries should be performed, and potentially waiting for some time before the next retry attempt.
retryRPC(AbstractClient.RpcCallable<V>, Logger, String, String, Object...) - Method in class alluxio.AbstractClient
Tries to execute an RPC defined as a AbstractClient.RpcCallable.
retryRPC(RetryPolicy, AbstractClient.RpcCallable<V>, Logger, String, String, Object...) - Method in class alluxio.AbstractClient
 
RetryUtils - Class in alluxio.retry
Utilities for performing retries.
RetryUtils.RunnableThrowsIOException - Interface in alluxio.retry
Interface for methods which return nothing and may throw IOException.
reverseResolve(AlluxioURI) - Method in class alluxio.client.file.DelegatingFileSystem
 
reverseResolve(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Reverse resolve a ufs uri.
reverseResolve(AlluxioURI) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
reverseResolve(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Reverse resolve a ufs uri.
reverseResolve(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
reverseResolve(AlluxioURI) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
reverseResolve(ReverseResolvePRequest, StreamObserver<ReverseResolvePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Reverse resolve a ufs path.
reverseResolve(ReverseResolvePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Reverse resolve a ufs path.
reverseResolve(ReverseResolvePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Reverse resolve a ufs path.
reverseResolve(ReverseResolvePRequest, StreamObserver<ReverseResolvePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Reverse resolve a ufs path.
reverseResolve(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
reverseResolve(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Reverse path resolve a ufs uri to an Alluxio path.
reverseResolve(ReverseResolvePRequest, StreamObserver<ReverseResolvePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
reverseResolve(AlluxioURI) - Method in class alluxio.master.file.meta.MountTable
Resolves the given Ufs path.
ReverseResolvePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ReverseResolvePRequest
ReverseResolvePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ReverseResolvePRequest
ReverseResolvePRequestOrBuilder - Interface in alluxio.grpc
 
ReverseResolvePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ReverseResolvePResponse
ReverseResolvePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ReverseResolvePResponse
ReverseResolvePResponseOrBuilder - Interface in alluxio.grpc
 
REVISION - Static variable in class alluxio.ProjectConstants
 
REVISION_FIELD_NUMBER - Static variable in class alluxio.grpc.BuildVersion
 
REVISION_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPOptions
 
REVISION_SHORT - Static variable in class alluxio.RuntimeConstants
 
revokeLease(AlluxioEtcdClient.Lease) - Method in class alluxio.membership.AlluxioEtcdClient
Revoke given lease.
RmCommand - Class in alluxio.cli.fs.command
Removes the file specified by argv.
RmCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.RmCommand
 
rmdir(String) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
rmdir(String) - Method in class alluxio.fuse.StackFS
 
rmdir(String) - Method in interface alluxio.jnifuse.FuseFileSystem
 
rmdirCallback(String) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
ROCKS_BLOCK_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
ROCKS_BLOCK_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
ROCKS_CLOSE_WAIT_TIMEOUT - Static variable in class alluxio.rocks.RocksStore
 
ROCKS_INODE_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
ROCKS_INODE_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
ROCKS_OPEN_RETRY_TIMEOUT - Static variable in class alluxio.rocks.RocksStore
 
RocksBenchBase - Class in alluxio.inode
 
RocksBenchConfig - Class in alluxio.inode
This class is used to set different RocksDB configurations for the benchmarks through the mRocksConfig option, as follows: mRocksConfig - if using rocks, or rocksCache for mType, then the type of RocksDB configuration to use (if using heap then this option must be set to javaConfig).
RocksBenchConfig() - Constructor for class alluxio.inode.RocksBenchConfig
 
RocksBenchRead - Class in alluxio.inode
This benchmark measures the performance of RocksDB single key accesses.
RocksBenchRead() - Constructor for class alluxio.inode.RocksBenchRead
 
RocksBenchRead.Db - Class in alluxio.inode
 
RocksBenchRead.ThreadState - Class in alluxio.inode
 
RocksBenchReadWrite - Class in alluxio.inode
This benchmark measures the performance of RocksDB single key read and write operations that are interleaved.
RocksBenchReadWrite() - Constructor for class alluxio.inode.RocksBenchReadWrite
 
RocksBenchReadWrite.Db - Class in alluxio.inode
 
RocksBenchReadWrite.ThreadState - Class in alluxio.inode
 
RocksBenchWrite - Class in alluxio.inode
This benchmark measures the performance of writing single keys/value pairs of inodeId/inode to RocksDB.
RocksBenchWrite() - Constructor for class alluxio.inode.RocksBenchWrite
 
RocksBenchWrite.Db - Class in alluxio.inode
 
RocksBenchWrite.ThreadState - Class in alluxio.inode
 
RocksBlockMetaStore - Class in alluxio.master.metastore.rocks
Block store backed by RocksDB.
RocksBlockMetaStore(String) - Constructor for class alluxio.master.metastore.rocks.RocksBlockMetaStore
Creates and initializes a rocks block store.
RocksCheckpointed - Interface in alluxio.rocks
Provides default implementations for checkpointing RocksDB databases.
RocksDBDoraMetaStore - Class in alluxio.worker.dora
Dora Meta Store in RocksDB.
RocksDBDoraMetaStore(String, long) - Constructor for class alluxio.worker.dora.RocksDBDoraMetaStore
Creates and initializes a rocks block store.
RocksExclusiveLockHandle - Class in alluxio.master.metastore.rocks
This is a handle used to manage the write lock(exclusive lock) on RocksStore.
RocksExclusiveLockHandle(Callable<Void>) - Constructor for class alluxio.master.metastore.rocks.RocksExclusiveLockHandle
The constructor.
RocksInodeStore - Class in alluxio.master.metastore.rocks
File store backed by RocksDB.
RocksInodeStore(String) - Constructor for class alluxio.master.metastore.rocks.RocksInodeStore
Creates and initializes a rocks block store.
RocksSharedLockHandle - Class in alluxio.master.metastore.rocks
This is a handle used to manage a read lock(shared lock) on RocksStore.
RocksSharedLockHandle(int, LongAdder) - Constructor for class alluxio.master.metastore.rocks.RocksSharedLockHandle
The constructor.
RocksStore - Class in alluxio.rocks
Class for managing a rocksdb database.
RocksStore(String, String, String, DBOptions, Collection<ColumnFamilyDescriptor>, List<AtomicReference<ColumnFamilyHandle>>, boolean) - Constructor for class alluxio.rocks.RocksStore
 
RocksUtils - Class in alluxio.master.metastore.rocks
Convenience methods for working with RocksDB.
RocksUtils.RocksIteratorParser<T> - Interface in alluxio.master.metastore.rocks
Used to parse current RocksIterator element.
ROLE_FUSE - Static variable in class alluxio.cli.LogLevel
 
ROLE_JOB_MASTER - Static variable in class alluxio.cli.LogLevel
 
ROLE_JOB_MASTERS - Static variable in class alluxio.cli.LogLevel
 
ROLE_JOB_WORKER - Static variable in class alluxio.cli.LogLevel
 
ROLE_JOB_WORKERS - Static variable in class alluxio.cli.LogLevel
 
ROLE_MASTER - Static variable in class alluxio.cli.LogLevel
 
ROLE_MASTERS - Static variable in class alluxio.cli.LogLevel
 
ROLE_VALUE - Static variable in enum alluxio.grpc.table.PrincipalType
ROLE = 1;
ROLE_WORKER - Static variable in class alluxio.cli.LogLevel
 
ROLE_WORKERS - Static variable in class alluxio.cli.LogLevel
 
ROOT - Static variable in class alluxio.master.file.meta.MountTable
 
ROOT_INODE_NAME - Static variable in class alluxio.master.file.meta.InodeTree
Only the root inode should have the empty string as its name.
ROOT_MOUNT_ID - Static variable in class alluxio.util.IdUtils
 
ROOT_PATH - Static variable in class alluxio.master.file.meta.InodeTree
Path of the root inode.
RoundRobinWorkerAssignPolicy - Class in alluxio.master.job
Policy which employs Round Robin around given workers to select worker.
RoundRobinWorkerAssignPolicy() - Constructor for class alluxio.master.job.RoundRobinWorkerAssignPolicy
 
Route - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.Route
Route.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.Route
ROUTE_FIELD_NUMBER - Static variable in class alluxio.grpc.RouteFailure
 
RouteFailure - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RouteFailure
RouteFailure.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.RouteFailure
RouteFailureOrBuilder - Interface in alluxio.grpc
 
RouteOrBuilder - Interface in alluxio.grpc
 
ROUTES_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyRequest
 
ROUTES_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveRequest
 
RPC_PORT_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
RPC_PORT = 2;
RpcContext - Class in alluxio.master.file
Context passed through the span of a file system master RPC to manage actions that need to be taken when the body of the RPC is finished.
RpcContext(BlockDeletionContext, JournalContext, OperationContext) - Constructor for class alluxio.master.file.RpcContext
Creates an RpcContext.
RpcExecutorType - Enum in alluxio.executor
RPC ExecutorService types.
RPCHandler(Promise<ProtoMessage>) - Constructor for class alluxio.network.netty.NettyRPC.RPCHandler
Creates an instance of NettyRPC.RPCHandler.
RPCMessage - Class in alluxio.network.protocol
This is the main base class for all RPC messages to the DataServer.
RPCMessage() - Constructor for class alluxio.network.protocol.RPCMessage
 
RPCMessage.Type - Enum in alluxio.network.protocol
The possible types of RPC messages.
RPCMessageDecoder - Class in alluxio.network.protocol
Simple Netty decoder which converts the input ByteBuf into an RPCMessage.
RPCMessageDecoder() - Constructor for class alluxio.network.protocol.RPCMessageDecoder
Constructs a new RPCMessageDecoder.
RPCMessageEncoder - Class in alluxio.network.protocol
Simple Netty encoder for RPCMessages.
RPCMessageEncoder() - Constructor for class alluxio.network.protocol.RPCMessageEncoder
Constructs a new RPCMessageEncoder.
RPCPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
RPCPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.NetAddress
 
RPCPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
 
RpcPortHealthCheckClient - Class in alluxio.common
RpcPortHealthCheckClient check if worker is serving RPC.
RpcPortHealthCheckClient(InetSocketAddress, ServiceType, Supplier<RetryPolicy>, AlluxioConfiguration) - Constructor for class alluxio.common.RpcPortHealthCheckClient
Creates a worker health check client.
RPCProtoMessage - Class in alluxio.network.protocol
This is the main base class for all protocol buffer based RPC messages to the DataServer.
RPCProtoMessage(ProtoMessage, DataBuffer) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage.
RPCProtoMessage(ProtoMessage) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage without data part.
RPCProtoMessage(byte[], ProtoMessage, DataBuffer) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage from a serialized proto message.
RpcSensitiveConfigMask - Class in alluxio
RpcSensitiveConfigMask is going to mask the credential RPC messages.
RpcSensitiveConfigMask() - Constructor for class alluxio.RpcSensitiveConfigMask
 
RpcServerService - Class in alluxio.master.service.rpc
RpcServerService(InetSocketAddress, MasterProcess, MasterRegistry) - Constructor for class alluxio.master.service.rpc.RpcServerService
 
RpcServerService.Factory - Class in alluxio.master.service.rpc
Factory to create an RpcServerService.
RpcServerStandbyGrpcService - Class in alluxio.master.service.rpc
RpcServerStandbyGrpcService(InetSocketAddress, MasterProcess, MasterRegistry) - Constructor for class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
RpcUtils - Class in alluxio
Utilities for handling server RPC calls.
RpcUtils.NettyRPCCallable<T> - Interface in alluxio
An interface representing a netty RPC callable.
RpcUtils.RpcCallableThrowsIOException<T> - Interface in alluxio
An interface representing a callable which can only throw Alluxio or IO exceptions.
RpcUtils.StreamingRpcCallable<T> - Interface in alluxio
An interface representing a streaming RPC callable.
RpcUtilsBench - Class in alluxio
Benchmarks for RpcUtils.
RpcUtilsBench() - Constructor for class alluxio.RpcUtilsBench
 
RpcUtilsBench.BenchParams - Class in alluxio
 
run(String...) - Method in class alluxio.cli.AbstractShell
Handles the specified shell command request, displaying usage if the command format is invalid.
run(CommandLine) - Method in class alluxio.cli.bundler.command.CollectConfigCommand
 
run(CommandLine) - Method in class alluxio.cli.bundler.command.CollectJvmInfoCommand
 
run(CommandLine) - Method in class alluxio.cli.bundler.command.CollectLogCommand
 
run(CommandLine) - Method in class alluxio.cli.bundler.command.CollectMetricsCommand
 
run(CommandLine) - Method in class alluxio.cli.bundler.command.ExecuteShellCollectInfoCommand
 
run(AlluxioURI, String[]) - Method in class alluxio.cli.command.metadatacache.AbstractMetadataCacheSubCommand
 
run(CommandLine) - Method in interface alluxio.cli.Command
Runs the command.
run(CommandLine) - Method in class alluxio.cli.extensions.command.InstallCommand
 
run(CommandLine) - Method in class alluxio.cli.extensions.command.LsCommand
 
run(CommandLine) - Method in class alluxio.cli.extensions.command.UninstallCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CatCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CheckCachedCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChecksumCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChgrpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChmodCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ChownCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.ConsistentHashCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.CpCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.HeadCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.HelpCommand
 
run() - Method in class alluxio.cli.fs.command.job.JobAttempt
Runs the job.
run(CommandLine) - Method in class alluxio.cli.fs.command.LoadCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LocationCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.LsCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MkdirCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.MvCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.TailCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.TestCommand
 
run(CommandLine) - Method in class alluxio.cli.fs.command.TouchCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.EnableWorkerCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
run() - Method in class alluxio.cli.fsadmin.doctor.ConfigurationCommand
Runs doctor configuration command.
run() - Method in class alluxio.cli.fsadmin.doctor.StorageCommand
Runs doctor storage command.
run(CommandLine) - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
run(CommandLine) - Method in class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
 
run() - Method in class alluxio.cli.fsadmin.report.JobServiceMetricsCommand
Runs a job services report metrics command.
run() - Method in class alluxio.cli.fsadmin.report.MetricsCommand
Runs report metrics command.
run() - Method in class alluxio.cli.fsadmin.report.ProxyCommand
Runs a proxy report command.
run() - Method in class alluxio.cli.fsadmin.report.SummaryCommand
Runs report summary command.
run() - Method in class alluxio.cli.fsadmin.report.UfsCommand
Runs report ufs command.
run(AlluxioURI, String[]) - Method in interface alluxio.cli.FuseCommand
Runs the command.
run(String[]) - Method in class alluxio.cli.RunOperation
 
run() - Method in class alluxio.cli.UnderFileSystemContractTest
Runs the tests and returns nothing.
run() - Method in class alluxio.client.file.dora.netty.NettyDataReaderStateMachine
Starts the state machine.
run(JobConfig, int, AlluxioConfiguration) - Static method in class alluxio.client.job.JobGrpcClientUtils
Runs the specified job and waits for it to finish.
run(JobConfig) - Method in interface alluxio.client.job.JobMasterClient
Starts a plan based on the given configuration.
run(JobConfig) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
run() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
This method is required to be public, but should never be called explicitly.
run() - Method in class alluxio.examples.Performance.AlluxioReadWorker
 
run() - Method in class alluxio.examples.Performance.AlluxioWriterWorker
 
run() - Method in class alluxio.examples.Performance.GeneralWorker
 
run() - Method in class alluxio.examples.Performance.HdfsWorker
 
run(RunPRequest, StreamObserver<RunPResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Starts the given job, returning a job id.
run(RunPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Starts the given job, returning a job id.
run(RunPRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Starts the given job, returning a job id.
run(RunPRequest, StreamObserver<RunPResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Starts the given job, returning a job id.
run() - Method in class alluxio.heartbeat.HeartbeatThread
 
RUN - Static variable in class alluxio.job.ServiceConstants
 
run(BlockWorkerClient) - Method in class alluxio.master.job.CopyJob.CopyTask
 
run(BlockWorkerClient) - Method in class alluxio.master.job.DoraLoadJob.DoraLoadTask
 
run(JobConfig) - Method in class alluxio.master.job.JobMaster
Runs a job with the given configuration.
run(JobConfig, long) - Method in class alluxio.master.job.JobMaster
Runs a job with the given configuration and job id.
run(JobConfig) - Method in class alluxio.master.job.JobMasterClientRestServiceHandler
Runs a job.
run(RunPRequest, StreamObserver<RunPResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
run(BlockWorkerClient) - Method in class alluxio.master.job.LoadJob.LoadTask
 
run(BlockWorkerClient) - Method in class alluxio.master.job.MoveJob.MoveTask
 
run(PlanConfig, CommandManager, JobServerContext, List<WorkerInfo>, long) - Method in class alluxio.master.job.plan.PlanTracker
Adds a job with the given JobConfig to the job tracker.
run(CmdConfig, long) - Method in class alluxio.master.job.tracker.CmdJobTracker
Run the PlanTracker to trigger a Cmd job based on CmdConfig.
run() - Method in class alluxio.master.job.tracker.CmdRunAttempt
Runs the job.
run(WorkflowConfig, long) - Method in class alluxio.master.job.workflow.WorkflowTracker
Runs a workflow with the given configuration and job id.
run() - Method in class alluxio.master.journal.AbstractCatchupThread
 
run() - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
 
run() - Method in class alluxio.master.MasterHealthCheckClient.MasterServingHealthCheck
 
run() - Method in class alluxio.master.MasterHealthCheckClient.ProcessCheckRunnable
 
run() - Method in class alluxio.network.RejectingServer
 
run(Process) - Static method in class alluxio.ProcessUtils
Runs the given Process.
run() - Method in class alluxio.proxy.s3.MultipartUploadCleaner.AbortTask
 
run() - Method in interface alluxio.retry.RetryUtils.RunnableThrowsIOException
Runs the runnable.
run(BlockWorkerClient) - Method in class alluxio.scheduler.job.Task
run the task.
run() - Method in class alluxio.shell.ShellCommand
Runs a command and returns its stdout on success.
run(String[]) - Method in class alluxio.stress.cli.AbstractStressBench
 
run(String[]) - Method in class alluxio.stress.cli.Benchmark
Runs the test and returns the string output.
run(String[]) - Method in class alluxio.stress.cli.report.GenerateReport
Runs the report generation tool.
run() - Method in class alluxio.worker.dora.DoraOpenFileHandleContainer
 
run() - Method in class alluxio.worker.job.task.TaskExecutor
 
run() - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
Start the state machine.
run() - Method in class alluxio.worker.SessionCleaner
Main loop for the cleanup, continuously looks for zombie sessions.
runAfterBoth(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, executes the given action.
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, executes the given action using this stage's default asynchronous execution facility.
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, executes the given action using the supplied executor.
runAfterEither(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, executes the given action.
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, executes the given action using this stage's default asynchronous execution facility.
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, executes the given action using the supplied executor.
runAllTests() - Method in class alluxio.cli.HdfsValidationTool
 
runAllTests() - Method in class alluxio.cli.HmsValidationTool
 
runAllTests() - Method in interface alluxio.cli.ValidationTool
Runs validation tests.
runAsync(Runnable) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the ForkJoinPool.commonPool() after it runs the given action.
runAsync(Runnable, Executor) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the given executor after it runs the given action.
RUNASYNC_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPOptions
 
runCatchup() - Method in class alluxio.master.journal.AbstractCatchupThread
Does the work of catching up.
runCommand(AlluxioURI) - Method in class alluxio.cli.FuseShell
 
runDistCp(AlluxioURI, AlluxioURI, boolean, int, long) - Method in class alluxio.master.job.tracker.MigrateCliRunner
Run a DistCp command.
runExample(Callable<Boolean>) - Static method in class alluxio.cli.RunTestUtils
Runs an example.
runLocal() - Method in class alluxio.stress.cli.Benchmark
Runs the test locally, in process.
runLocal() - Method in class alluxio.stress.cli.client.StressClientIOBench
 
runLocal() - Method in class alluxio.stress.cli.UfsIOBench
 
runLocal() - Method in class alluxio.stress.cli.worker.StressWorkerBench
 
runNextPendingCommand() - Method in class alluxio.util.executor.ControllableScheduler
Runs the next command scheduled to be executed immediately.
Running_VALUE - Static variable in enum alluxio.grpc.BackupState
Running = 4;
RUNNING_VALUE - Static variable in enum alluxio.grpc.Status
RUNNING = 4;
RunOperation - Class in alluxio.cli
Class for running an operation multiple times.
RunOperation(AlluxioConfiguration) - Constructor for class alluxio.cli.RunOperation
Constructs a new RunOperation object.
runPersistJob(PersistCmdConfig, long) - Method in class alluxio.master.job.tracker.PersistRunner
Run a Persist job.
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.AbstractFileSystemCommand
Runs the command for a particular URI that does not contain wildcard in its path.
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.CatCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChecksumCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChgrpCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChmodCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.ChownCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.HeadCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.LoadCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.LocationCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.LsCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.TailCommand
 
runPlainPath(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.TouchCommand
 
RunPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunPOptions
RunPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunPOptions
RunPOptionsOrBuilder - Interface in alluxio.grpc
 
RunPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunPRequest
RunPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunPRequest
RunPRequestOrBuilder - Interface in alluxio.grpc
 
RunPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunPResponse
RunPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunPResponse
RunPResponseOrBuilder - Interface in alluxio.grpc
 
runSingleTask(String[]) - Method in class alluxio.stress.cli.Benchmark
 
runSubCommand(AlluxioURI, String[], MetadataCachingFileSystem) - Method in class alluxio.cli.command.metadatacache.AbstractMetadataCacheSubCommand
Run the metadatacache subcommand.
runSubCommand(AlluxioURI, String[], MetadataCachingFileSystem) - Method in class alluxio.cli.command.metadatacache.DropAllCommand
 
runSubCommand(AlluxioURI, String[], MetadataCachingFileSystem) - Method in class alluxio.cli.command.metadatacache.DropCommand
 
runSubCommand(AlluxioURI, String[], MetadataCachingFileSystem) - Method in class alluxio.cli.command.metadatacache.SizeCommand
 
runTask(BatchedJobConfig, BatchedJobDefinition.BatchedJobTask, RunTaskContext) - Method in class alluxio.job.plan.batch.BatchedJobDefinition
 
runTask(MigrateConfig, MigrateCommand, RunTaskContext) - Method in class alluxio.job.plan.migrate.MigrateDefinition
Runs the task in the executor.
runTask(NoopPlanConfig, SerializableVoid, RunTaskContext) - Method in class alluxio.job.plan.NoopPlanDefinition
 
runTask(PersistConfig, SerializableVoid, RunTaskContext) - Method in class alluxio.job.plan.persist.PersistDefinition
 
runTask(T, P, RunTaskContext) - Method in interface alluxio.job.plan.PlanDefinition
Runs the task in the executor.
runTask(MoveConfig, SerializableVoid, RunTaskContext) - Method in class alluxio.job.plan.replicate.MoveDefinition
Runs the task in the executor.
runTask(StressBenchConfig, ArrayList<String>, RunTaskContext) - Method in class alluxio.job.plan.stress.StressBenchDefinition
 
RunTaskCommand - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunTaskCommand
RunTaskCommand.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.RunTaskCommand
RUNTASKCOMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobCommand
 
RunTaskCommandOrBuilder - Interface in alluxio.grpc
 
RunTaskContext - Class in alluxio.job
A context which contains useful information that can be used when running a task on a job worker.
RunTaskContext(long, long, JobServerContext) - Constructor for class alluxio.job.RunTaskContext
Creates an instance of RunTaskContext.
RunTestUtils - Class in alluxio.cli
Utilities to run the examples.
RUNTIME - Static variable in class alluxio.conf.Source
 
RuntimeConstants - Class in alluxio
System constants that are determined during runtime.
runValidationTask() - Method in class alluxio.cli.UnderFileSystemContractTest
Runs the tests and return a ValidationTaskResult.
runWildCardCmd(AlluxioURI, CommandLine) - Method in class alluxio.cli.fs.command.AbstractFileSystemCommand
Runs the command for a particular URI that may contain wildcard in its path.
runWithOutput() - Method in class alluxio.shell.ShellCommand
Runs a command and returns its output and exit code in Object.
RWLockResource - Class in alluxio.resource
The RWLockResource is an extension of the LockResource which allows for downgrading of locks.
RWLockResource(ReentrantReadWriteLock, LockMode, boolean, boolean) - Constructor for class alluxio.resource.RWLockResource
Creates a new instance of RW lock that will lock with the given mode.

S

S3_ACCEPT_RANGES_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_ACCEPT_RANGES_VALUE - Static variable in class alluxio.s3.S3Constants
 
S3_ACL_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_CONTENT_LENGTH_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_CONTENT_RANGE_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_CONTENT_TYPE_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_COPY_SOURCE_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_COPY_SOURCE_RANGE - Static variable in class alluxio.s3.S3Constants
 
S3_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
Cost map is a map between ufs operations and their associated cost in dollars per operation.
S3_DATE_FORMAT_REGEXP - Static variable in class alluxio.s3.S3Constants
 
S3_DELETE_IN_ALLUXIO_AND_UFS - Static variable in class alluxio.Constants
 
S3_DELETE_IN_ALLUXIO_ONLY - Static variable in class alluxio.Constants
 
S3_ETAG_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_HANDLER_ATTRIBUTE - Static variable in class alluxio.web.ProxyWebServer
 
S3_METADATA_DIRECTIVE_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_METADATA_ROOT_DIR - Static variable in class alluxio.s3.S3Constants
 
S3_METADATA_UPLOADS_DIR - Static variable in class alluxio.s3.S3Constants
 
S3_MULTIPART_PART_PREFIX - Static variable in class alluxio.s3.S3Constants
 
S3_REST_AUTHENTICATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
S3_REST_AUTHENTICATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
S3_REST_AUTHENTICATOR_CLASSNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
S3_REST_AUTHENTICATOR_CLASSNAME - Static variable in class alluxio.conf.PropertyKey
 
S3_SIGN_ALGORITHM - Static variable in class alluxio.s3.S3Constants
 
S3_SIGN_CONTENT_SHA256 - Static variable in class alluxio.s3.S3Constants
 
S3_SIGN_CREDENTIAL - Static variable in class alluxio.s3.S3Constants
 
S3_SIGN_DATE - Static variable in class alluxio.s3.S3Constants
 
S3_SIGN_EXPIRES - Static variable in class alluxio.s3.S3Constants
 
S3_SIGN_SIGNATURE - Static variable in class alluxio.s3.S3Constants
 
S3_SIGN_SIGNED_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_STANDARD_STORAGE_CLASS - Static variable in class alluxio.s3.S3Constants
 
S3_TAGGING_COUNT_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_TAGGING_DIRECTIVE_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_TAGGING_HEADER - Static variable in class alluxio.s3.S3Constants
 
S3_UPLOADS_ID_XATTR_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
S3_V2_SERVICE_PATH_PREFIX - Static variable in class alluxio.proxy.s3.S3RequestServlet
 
S3_WRITE_TYPE - Static variable in class alluxio.worker.s3.S3NettyHandler
 
S3A_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
S3A_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
S3A_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
S3A_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
S3AInputStream - Class in alluxio.underfs.s3a
An S3A input stream that supports skip and seek efficiently.
S3AInputStream(String, String, AmazonS3, long, RetryPolicy) - Constructor for class alluxio.underfs.s3a.S3AInputStream
Constructor for an input stream of an object in s3 using the aws-sdk implementation to read the data.
S3ALowLevelOutputStream - Class in alluxio.underfs.s3a
Object storage low output stream for aws s3.
S3ALowLevelOutputStream(String, String, AmazonS3, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.s3a.S3ALowLevelOutputStream
Constructs a new stream for writing a file.
S3AMultipartUploadOutputStream - Class in alluxio.underfs.s3a
Object storage multipart upload for aws s3.
S3AMultipartUploadOutputStream(String, String, AmazonS3, ListeningExecutorService, AlluxioConfiguration) - Constructor for class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
Constructs a new stream for writing a file.
S3AOutputStream - Class in alluxio.underfs.s3a
A stream for writing a file into S3.
S3AOutputStream(String, String, TransferManager, List<String>, boolean) - Constructor for class alluxio.underfs.s3a.S3AOutputStream
Constructs a new stream for writing a file.
S3APositionReader - Class in alluxio.underfs.s3a
Implementation of ObjectPositionReader that reads from S3A object store.
S3APositionReader(AmazonS3, String, String, long) - Constructor for class alluxio.underfs.s3a.S3APositionReader
 
S3ASpecificOperations - Class in alluxio.cli
Examples for S3A specific under filesystem operations.
S3ASpecificOperations(String, UnderFileSystem, InstancedConfiguration) - Constructor for class alluxio.cli.S3ASpecificOperations
 
S3AuditContext - Class in alluxio.s3
An audit context for s3 rest service.
S3AuditContext(AsyncUserAccessAuditLogWriter) - Constructor for class alluxio.s3.S3AuditContext
Constructor of S3AuditContext.
S3AUnderFileSystem - Class in alluxio.underfs.s3a
S3 UnderFileSystem implementation based on the aws-java-sdk-s3 library.
S3AUnderFileSystem(AlluxioURI, AmazonS3, S3AsyncClient, String, ExecutorService, TransferManager, UnderFileSystemConfiguration, boolean, boolean) - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystem
Constructor for S3AUnderFileSystem.
S3AUnderFileSystem.S3AObjectListingChunk - Class in alluxio.underfs.s3a
Wrapper over S3 ListObjectsV2Request.
S3AUnderFileSystem.S3AObjectListingChunkV1 - Class in alluxio.underfs.s3a
Wrapper over S3 ListObjectsRequest.
S3AUnderFileSystemFactory - Class in alluxio.underfs.s3a
Factory for creating S3AUnderFileSystem.
S3AUnderFileSystemFactory() - Constructor for class alluxio.underfs.s3a.S3AUnderFileSystemFactory
Constructs a new S3AUnderFileSystemFactory.
S3AuthenticationFilter - Class in alluxio.proxy.s3
Authentication filter for S3 API.
S3AuthenticationFilter() - Constructor for class alluxio.proxy.s3.S3AuthenticationFilter
 
S3AUtils - Class in alluxio.underfs.s3a
Util functions for S3A under file system.
S3BaseTask - Class in alluxio.proxy.s3
S3 Abstract Base task for handling S3 API logic.
S3BaseTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3BaseTask
Instantiate a S3BaseTask.
S3BaseTask.OpTag - Enum in alluxio.proxy.s3
Enum for tagging the http request to target for different threadpools for handling.
S3BaseTask.OpType - Enum in alluxio.proxy.s3
Enum indicating name of S3 API handling per http request.
S3BucketTask - Class in alluxio.proxy.s3
S3 Tasks to handle bucket level or global level request.
S3BucketTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3BucketTask
 
S3BucketTask.Factory - Class in alluxio.proxy.s3
Factory for getting a S3BucketTask type task.
S3Constants - Class in alluxio.s3
Constants for S3 northbound API.
S3Constants.Directive - Enum in alluxio.s3
Directive specifies whether metadata/tag-set are copied from the source object or replaced with metadata/tag-set provided in the request.
S3Error - Class in alluxio.s3
Error response defined in http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html.
S3Error() - Constructor for class alluxio.s3.S3Error
Creates an S3Error.
S3Error(String, S3ErrorCode) - Constructor for class alluxio.s3.S3Error
Creates a new Error.
S3ErrorCode - Class in alluxio.s3
Error codes defined in http://docs.aws.amazon.com/AmazonS3/latest/API/ErrorResponses.html with API version 2006-03-01.
S3ErrorCode(String, String, Response.Status) - Constructor for class alluxio.s3.S3ErrorCode
Constructs a new S3ErrorCode.
S3ErrorCode.Name - Class in alluxio.s3
Error code names used in S3ErrorCode.
S3ErrorResponse - Class in alluxio.s3
Utilities for creating HTTP Responses for the S3 API.
S3ErrorResponse() - Constructor for class alluxio.s3.S3ErrorResponse
 
S3Exception - Exception in alluxio.s3
An exception thrown during processing S3 REST requests.
S3Exception(S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
Constructs a new S3Exception.
S3Exception(String, S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
Constructs a new S3Exception.
S3Exception(Exception, String, S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
Derives a new S3Exception from an existing exception.
S3Exception(String, String, S3ErrorCode) - Constructor for exception alluxio.s3.S3Exception
Derives a new S3Exception from an existing exception.
S3Handler - Class in alluxio.proxy.s3
 
S3Handler(String, String, HttpServletRequest, HttpServletResponse) - Constructor for class alluxio.proxy.s3.S3Handler
S3Handler Constructor.
S3HttpHandler - Class in alluxio.worker.s3
Handles S3 HTTP request.
S3HttpHandler(FileSystem, DoraWorker, AsyncUserAccessAuditLogWriter, ThreadPoolExecutor, ThreadPoolExecutor) - Constructor for class alluxio.worker.s3.S3HttpHandler
Constructs an instance of S3HttpHandler.
S3HttpPipelineHandler - Class in alluxio.worker.s3
Adds the http server's pipeline into the channel.
S3HttpPipelineHandler(FileSystem, DoraWorker) - Constructor for class alluxio.worker.s3.S3HttpPipelineHandler
Constructs an instance of S3HttpPipelineHandler.
S3NettyBaseTask - Class in alluxio.worker.s3
S3 Abstract Base task for handling S3 API logic in netty server.
S3NettyBaseTask(S3NettyHandler, S3NettyBaseTask.OpType) - Constructor for class alluxio.worker.s3.S3NettyBaseTask
Creates an instance of S3NettyBaseTask.
S3NettyBaseTask.OpTag - Enum in alluxio.worker.s3
Enum for tagging the http request to target for different threadpools for handling.
S3NettyBaseTask.OpType - Enum in alluxio.worker.s3
Enum indicating name of S3 API handling per http request.
S3NettyBucketTask - Class in alluxio.worker.s3
S3 Netty Tasks to handle bucket level or global level request.
S3NettyBucketTask(S3NettyHandler, S3NettyBaseTask.OpType) - Constructor for class alluxio.worker.s3.S3NettyBucketTask
Constructs an instance of S3NettyBucketTask.
S3NettyBucketTask.Factory - Class in alluxio.worker.s3
Factory for getting a S3BucketTask type task.
S3NettyHandler - Class in alluxio.worker.s3
S3 Netty Handler - handle http requests from S3 API in Netty.
S3NettyHandler(String, String, HttpRequest, ChannelHandlerContext, FileSystem, DoraWorker, AsyncUserAccessAuditLogWriter) - Constructor for class alluxio.worker.s3.S3NettyHandler
Constructs an instance of S3NettyHandler.
S3NettyObjectTask - Class in alluxio.worker.s3
S3 Netty Tasks to handle object level request.
S3NettyObjectTask(S3NettyHandler, S3NettyBaseTask.OpType) - Constructor for class alluxio.worker.s3.S3NettyObjectTask
 
S3NettyObjectTask.Factory - Class in alluxio.worker.s3
Factory for getting a S3ObjectTask.
S3ObjectTask - Class in alluxio.proxy.s3
S3 Tasks to handle object level request.
S3ObjectTask(S3Handler, S3BaseTask.OpType) - Constructor for class alluxio.proxy.s3.S3ObjectTask
 
S3ObjectTask.CompleteMultipartUploadTask - Class in alluxio.proxy.s3
CompleteMultipartUploadTask.
S3ObjectTask.Factory - Class in alluxio.proxy.s3
Factory for getting a S3ObjectTask.
S3RangeSpec - Class in alluxio.s3
This class is Range Spec for Amazon S3 API.
S3RangeSpec(boolean) - Constructor for class alluxio.s3.S3RangeSpec
 
S3RangeSpec(long, long) - Constructor for class alluxio.s3.S3RangeSpec
 
S3RangeSpec.Factory - Class in alluxio.s3
Factory for S3RangeSpec.
S3RequestServlet - Class in alluxio.proxy.s3
New architecture Request Servlet for handling s3 requests in replacement of JAX-RS.
S3RequestServlet() - Constructor for class alluxio.proxy.s3.S3RequestServlet
 
S3RestExceptionMapper - Class in alluxio.proxy.s3
An exception mapper for REST PROXY to convert inner exception to HTTP Response.
S3RestExceptionMapper() - Constructor for class alluxio.proxy.s3.S3RestExceptionMapper
 
S3RestServiceHandler - Class in alluxio.proxy.s3
This class is a REST handler for Amazon S3 API.
S3RestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.s3.S3RestServiceHandler
Constructs a new S3RestServiceHandler.
S3RestUtils - Class in alluxio.proxy.s3
Utilities for handling S3 REST calls.
S3RestUtils.RestCallable<T> - Interface in alluxio.proxy.s3
An interface representing a callable.
S3RestUtils.URIStatusNameComparator - Class in alluxio.proxy.s3
Comparator based on uri name, treat uri name as a Long number.
S3SyntaxOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.S3SyntaxOptions
S3SyntaxOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.S3SyntaxOptions
S3SYNTAXOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.RenamePOptions
 
S3SyntaxOptionsOrBuilder - Interface in alluxio.grpc
 
S_CLIENT_ID_KEY - Static variable in class alluxio.security.authentication.ChannelIdInjector
Metadata key for the channel Id.
S_CLIENT_VERSION_KEY - Static variable in class alluxio.grpc.ClientVersionClientInjector
 
SAFE_MODE_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
SAFE_MODE = 3;
safeManagedBlock(ForkJoinPool.ManagedBlocker) - Static method in class alluxio.concurrent.ForkJoinPoolHelper
Does managed blocking on ForkJoinPool.
SAFEMODE_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
SafeModeManager - Interface in alluxio.master
Interface for managing safe mode state.
SafeUfsDeleter - Class in alluxio.master.file
Helper class for deleting persisted entries from the UFS.
SafeUfsDeleter(MountTable, ReadOnlyInodeStore, List<Pair<AlluxioURI, LockedInodePath>>, DeletePOptions) - Constructor for class alluxio.master.file.SafeUfsDeleter
Creates a new instance of SafeUfsDeleter.
SamplingLogger - Class in alluxio.util.logging
A logger which limits log message frequency to prevent spamming the logs.
SamplingLogger(Logger, long) - Constructor for class alluxio.util.logging.SamplingLogger
 
SaslAuthenticationServiceGrpc - Class in alluxio.grpc
 
SaslAuthenticationServiceGrpc.AsyncService - Interface in alluxio.grpc
 
SaslAuthenticationServiceGrpc.SaslAuthenticationServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service SaslAuthenticationService.
SaslAuthenticationServiceGrpc.SaslAuthenticationServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service SaslAuthenticationService.
SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service SaslAuthenticationService.
SaslAuthenticationServiceGrpc.SaslAuthenticationServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service SaslAuthenticationService.
SaslAuthenticationServiceImplBase() - Constructor for class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase
 
SaslClientHandler - Interface in alluxio.security.authentication
Interface for authentication scheme specific SaslClient management.
SaslClientHandlerPlain - Class in alluxio.security.authentication.plain
SaslClientHandler implementation for Plain/Custom schemes.
SaslClientHandlerPlain(Subject, AlluxioConfiguration) - Constructor for class alluxio.security.authentication.plain.SaslClientHandlerPlain
Creates SaslClientHandler instance for Plain/Custom.
SaslClientHandlerPlain(String, String, String) - Constructor for class alluxio.security.authentication.plain.SaslClientHandlerPlain
Creates SaslClientHandler instance for Plain/Custom.
SaslMessage - Class in alluxio.grpc
Protobuf type alluxio.grpc.sasl.SaslMessage
SaslMessage.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.sasl.SaslMessage
SaslMessageOrBuilder - Interface in alluxio.grpc
 
SaslMessageType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.sasl.SaslMessageType
SaslServerHandler - Interface in alluxio.security.authentication
Interface for authentication scheme specific SaslServer management.
SaslServerHandlerPlain - Class in alluxio.security.authentication.plain
SaslServerHandler implementation for Plain/Custom schemes.
SaslServerHandlerPlain(String, AlluxioConfiguration, ImpersonationAuthenticator) - Constructor for class alluxio.security.authentication.plain.SaslServerHandlerPlain
Creates SaslServerHandler for Plain/Custom.
saveWorkdir() - Method in class alluxio.multi.process.MultiProcessCluster
Copies the work directory to the artifacts folder.
sCachedGroupMapping - Static variable in class alluxio.security.group.GroupMappingService.Factory
 
SCALE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Decimal
 
SCANCOMPLETED_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
scanPages(Consumer<Optional<PageInfo>>) - Method in class alluxio.client.file.cache.store.LocalPageStoreDir
Gets a stream of all pages from the page store.
scanPages(Consumer<Optional<PageInfo>>) - Method in class alluxio.client.file.cache.store.MemoryPageStoreDir
 
scanPages(Consumer<Optional<PageInfo>>) - Method in interface alluxio.client.file.cache.store.PageStoreDir
Scan the pages under this dir.
SCANPENDINGACTION_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
scanRegistered(String, S) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Finds factories from registered collection.
SCANSTARTEDMS_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
SCANTOTAL_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
schedule(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Schedules execution of a heartbeat for the given thread.
schedule() - Method in class alluxio.heartbeat.ScheduledTimer
Schedules execution of the heartbeat.
schedule(Duration, Runnable) - Method in class alluxio.master.transport.GrpcMessagingContext
Submits a one-shot task that becomes enabled after the given delay.
schedule(Duration, Duration, Runnable) - Method in class alluxio.master.transport.GrpcMessagingContext
Submits a one-shot task that becomes enabled after the given delay.
schedule(Runnable, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
schedule(Callable<V>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
scheduleAsyncPersist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Schedules the async persistence of the given file.
scheduleAsyncPersist(AlluxioURI, ScheduleAsyncPersistencePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
scheduleAsyncPersistDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest, StreamObserver<ScheduleAsyncPersistencePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Schedules async persistence.
scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Schedules async persistence.
scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Schedules async persistence.
scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest, StreamObserver<ScheduleAsyncPersistencePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Schedules async persistence.
scheduleAsyncPersistence(AlluxioURI) - Method in interface alluxio.master.file.async.AsyncPersistHandler
Schedules a file for async persistence.
scheduleAsyncPersistence(AlluxioURI) - Method in class alluxio.master.file.async.DefaultAsyncPersistHandler
 
scheduleAsyncPersistence(AlluxioURI, ScheduleAsyncPersistenceContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
scheduleAsyncPersistence(AlluxioURI, ScheduleAsyncPersistenceContext) - Method in interface alluxio.master.file.FileSystemMaster
Schedules a file for async persistence.
scheduleAsyncPersistence(ScheduleAsyncPersistencePRequest, StreamObserver<ScheduleAsyncPersistencePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
ScheduleAsyncPersistenceContext - Class in alluxio.master.file.contexts
Used to merge and wrap ScheduleAsyncPersistencePOptions.
scheduleAsyncPersistenceDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
ScheduleAsyncPersistencePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePOptions
ScheduleAsyncPersistencePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePOptions
ScheduleAsyncPersistencePOptionsOrBuilder - Interface in alluxio.grpc
 
ScheduleAsyncPersistencePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePRequest
ScheduleAsyncPersistencePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePRequest
ScheduleAsyncPersistencePRequestOrBuilder - Interface in alluxio.grpc
 
ScheduleAsyncPersistencePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePResponse
ScheduleAsyncPersistencePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.ScheduleAsyncPersistencePResponse
ScheduleAsyncPersistencePResponseOrBuilder - Interface in alluxio.grpc
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
SCHEDULED_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
 
ScheduledTimer - Class in alluxio.heartbeat
This class can be used for controlling heartbeat execution of threads.
ScheduledTimer(String, Clock, Supplier<SleepIntervalSupplier>) - Constructor for class alluxio.heartbeat.ScheduledTimer
Creates a new instance of ScheduledTimer.
Scheduler - Class in alluxio.master.scheduler
The Scheduler which controls jobs.
Scheduler(FileSystemContext, WorkerProvider, JobMetaStore) - Constructor for class alluxio.master.scheduler.Scheduler
Constructor.
Scheduler.BoundedPriorityBlockingQueue<E> - Class in alluxio.master.scheduler
Bounded priority queue impl.
Scheduler.SchedulerStats - Class in alluxio.master.scheduler
Job/Tasks stats.
Scheduler.WorkerInfoHub - Class in alluxio.master.scheduler
Worker information hub.
Scheduler.WorkerInfoIdentity - Class in alluxio.master.scheduler
Util class here for tracking unique identity of a worker as WorkerInfo class uses constantly changing field such as mLastContactSec for equals(), which can't be served as key class in map.
SCHEDULER_INFO - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
scheduleRemoveFromWorker(long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Remove the block from the worker metadata and add to the to-remove list.
schedulerIsIdle() - Method in class alluxio.util.executor.ControllableScheduler
Reports whether scheduler has no commands/tasks pending immediate execution.
SchedulerStats() - Constructor for class alluxio.master.scheduler.Scheduler.SchedulerStats
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
Schema - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Schema
Schema.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Schema
SCHEMA_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
SchemaOrBuilder - Interface in alluxio.grpc.table
 
SCHEME - Static variable in class alluxio.Constants
 
scope(CacheScope) - Static method in interface alluxio.client.file.cache.CacheUsage.PartitionDescriptor
Creates a partition of a cache scope.
Scope - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.meta.Scope
Scoped - Interface in alluxio.util.interfaces
Extension of Closeable which throws no checked exceptions.
ScopeEncoder - Class in alluxio.client.file.cache.cuckoofilter
A scope encoder that supports encode/decode scope information.
ScopeEncoder(int) - Constructor for class alluxio.client.file.cache.cuckoofilter.ScopeEncoder
Create a scope encoder.
ScopePartition(CacheScope) - Constructor for class alluxio.client.file.cache.CacheUsage.ScopePartition
Creates a partition over a cache scope.
ScpCommand - Class in alluxio.shell
Object representation of a remote scp command.
ScpCommand(String, String, String) - Constructor for class alluxio.shell.ScpCommand
Creates a remote scp command to copy a file to local.
ScpCommand(String, String, String, boolean) - Constructor for class alluxio.shell.ScpCommand
Creates a remote scp command to copy a file/dir to local.
scpCommandWithOutput(String, String, String, boolean) - Static method in class alluxio.util.ShellUtils
Static method to execute an scp command to copy a remote file/dir to local.
sDoraCacheFileSystemFactory - Static variable in class alluxio.client.file.DoraCacheFileSystem
 
SECOND - Static variable in class alluxio.Constants
 
SECOND_MS - Static variable in class alluxio.Constants
 
SECOND_NANO - Static variable in class alluxio.Constants
 
SECOND_TIER - Static variable in class alluxio.Constants
 
SecureHdfsValidationTask - Class in alluxio.cli.hdfs
Task for validating security configurations.
SecureHdfsValidationTask(String, String, AlluxioConfiguration) - Constructor for class alluxio.cli.hdfs.SecureHdfsValidationTask
Constructor of SecureHdfsValidationTask for validating Kerberos login ability.
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_SERVER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
SECURITY_SERVER_CLIENT_SERVICE = 1005;
SECURITY_SERVER_VERSION - Static variable in class alluxio.Constants
 
SecurityUtils - Class in alluxio.jnifuse.utils
 
SecurityUtils - Class in alluxio.util
Utility methods for security.
seek(long) - Method in class alluxio.client.block.stream.SharedGrpcDataReader
Seeks to a specific position.
seek(long) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
seek(long) - Method in class alluxio.client.file.PositionReadFileInStream
 
seek(long) - Method in class alluxio.client.file.ufs.UfsFileInStream
 
seek(long) - Method in class alluxio.file.SeekableBufferedInputStream
 
seek(long) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
seek(long) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
seek(long) - Method in interface alluxio.Seekable
Moves the starting read position of the stream to the specified position which is relative to the start of the stream.
seek(long) - Method in class alluxio.underfs.cephfs.CephInputStream
Seek.
seek(long) - Method in class alluxio.underfs.cephfs.CephSeekableInputStream
 
seek(long) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
seek(long) - Method in class alluxio.underfs.hdfs.HdfsUnderFileInputStream
 
seek(long) - Method in class alluxio.underfs.s3a.S3AInputStream
 
Seekable - Interface in alluxio
This interface should be implemented by all Alluxio streams which support moving the read position to a specific byte offset.
SeekableBufferedInputStream - Class in alluxio.file
A class optimizes seekable input streams by providing buffering.
SeekableBufferedInputStream(InputStream, int) - Constructor for class alluxio.file.SeekableBufferedInputStream
Constructor.
SeekableUnderFileInputStream - Class in alluxio.underfs
A seekable under file input stream wrapper that encapsulates the under file input stream.
SeekableUnderFileInputStream(InputStream) - Constructor for class alluxio.underfs.SeekableUnderFileInputStream
 
seekToNewSource(long) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
This method is not supported in BaseHdfsFileInputStream.
SegmentedLock - Class in alluxio.client.file.cache.cuckoofilter
A segmented lock that supports methods to lock/unlock multiple buckets in order to avoid dead lock.
SegmentedLock(int, int) - Constructor for class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Create a segmented lock with specified locks.
selectExecutors(BatchedJobConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.batch.BatchedJobDefinition
 
selectExecutors(MigrateConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.migrate.MigrateDefinition
Selects the workers to run the task.
selectExecutors(NoopPlanConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.NoopPlanDefinition
 
selectExecutors(PersistConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.persist.PersistDefinition
 
selectExecutors(T, List<WorkerInfo>, SelectExecutorsContext) - Method in interface alluxio.job.plan.PlanDefinition
Selects the workers to run the task.
selectExecutors(MoveConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.replicate.MoveDefinition
 
selectExecutors(StressBenchConfig, List<WorkerInfo>, SelectExecutorsContext) - Method in class alluxio.job.plan.stress.StressBenchDefinition
 
SelectExecutorsContext - Class in alluxio.job
A context containing useful parameters for the job master to use when selecting the worker that a job should execute on.
SelectExecutorsContext(long, JobServerContext) - Constructor for class alluxio.job.SelectExecutorsContext
Creates a new instance of SelectExecutorsContext.
SelectionPolicyAnyMaster - Class in alluxio.master.selectionpolicy
The master selection policy that connects to a random master.
SelectionPolicyAnyMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
 
SelectionPolicyAnyStandbyMaster - Class in alluxio.master.selectionpolicy
The master connection mode that connects to a random standby master.
SelectionPolicyAnyStandbyMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
Creates a new standby connection mode that picks the standby master randomly.
SelectionPolicyAnyStandbyMaster(long) - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
Creates a new standby connection mode that picks the standby master deterministically with a random seed.
SelectionPolicyPrimaryMaster - Class in alluxio.master.selectionpolicy
The master selection policy that connects to the primary master.
SelectionPolicyPrimaryMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
 
SelectionPolicySpecifiedMaster - Class in alluxio.master.selectionpolicy
The master selection policy that connects to the specified master.
SelectionPolicySpecifiedMaster(InetSocketAddress) - Constructor for class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
Creates a new selection policy that specifies a master address to client.
send(ReqT, long) - Method in class alluxio.client.block.stream.GrpcBlockingStream
Sends a request.
send(ReqT) - Method in class alluxio.client.block.stream.GrpcBlockingStream
Sends a request.
send(Object) - Method in class alluxio.master.transport.GrpcMessagingConnection
Sends a request.
sendAndReceive(T) - Method in class alluxio.master.transport.GrpcMessagingConnection
Sends a request and receives a response.
sendAsync(Message) - Method in class alluxio.master.journal.raft.RaftJournalAppender
Sends a request to raft server asynchronously.
sendDataMessage(DataMessage<ReqT, DataBuffer>, long) - Method in class alluxio.client.block.stream.GrpcDataMessageBlockingStream
Sends a request.
sendMessageAsync(RaftPeerId, Message) - Method in class alluxio.master.journal.raft.RaftJournalSystem
Sends a message to a raft server asynchronously.
sendMessageAsync(RaftPeerId, Message, long) - Method in class alluxio.master.journal.raft.RaftJournalSystem
Sends a message to a raft server asynchronously.
sendMessageBlocking(GrpcMessagingConnection, Object) - Method in class alluxio.master.backup.AbstractBackupRole
Used to send message via connection and wait until response is received.
SENSITIVE_CONFIG_MASKER - Static variable in class alluxio.RpcUtils
 
SensitiveConfigMask - Interface in alluxio.conf
Mask some sensitive information.
SEPARATOR - Static variable in class alluxio.AlluxioURI
 
SEPARATOR - Static variable in class alluxio.cli.hdfs.HdfsConfValidationTask
 
SEPARATOR - Static variable in class alluxio.client.quota.CacheScope
 
SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
SERDE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.StorageFormat
 
SERDE_PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
SERDELIB_PARAMETERS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.StorageFormat
 
SerializableVoid - Class in alluxio.job.util
Same as Void, but implementing Serializable.
SerializationUtils - Class in alluxio.job.util
Serialization related utility methods.
serialize(T) - Method in class alluxio.grpc.DataMessageMarshaller
Serialize the message to buffers.
serialize(ReadResponse) - Method in class alluxio.grpc.ReadResponseMarshaller
 
serialize(WriteRequest) - Method in class alluxio.grpc.WriteRequestMarshaller
 
serialize(Object) - Static method in class alluxio.job.util.SerializationUtils
Serializes an object into a byte array.
serialize(Object, String) - Static method in class alluxio.job.util.SerializationUtils
Wrapper around SerializationUtils.serialize(Object) which throws a runtime exception with the given message on failure.
serialize(Journal.JournalEntry, OutputStream) - Method in interface alluxio.master.journalv0.JournalFormatter
Serializes the given entry and writes it to the given output stream.
serialize(Journal.JournalEntry, OutputStream) - Method in class alluxio.master.journalv0.ProtoBufJournalFormatter
 
serialize() - Method in class alluxio.membership.DefaultServiceEntity
Serialize the ServiceEntity to bytes.
serialize(TaggingData) - Static method in class alluxio.s3.TaggingData
Serializes the object as an XML (bytes).
serialize(AccessControlList, JsonGenerator, SerializerProvider) - Method in class alluxio.security.authorization.AccessControlList.AccessControlListSerializer
Serialize an AccessControlList object.
serialize() - Method in class alluxio.underfs.Fingerprint
 
serializer() - Method in class alluxio.master.transport.GrpcMessagingContext
 
server() - Method in class alluxio.master.transport.GrpcMessagingTransport
Creates a new Grpc messaging server.
Server<T> - Interface in alluxio
Interface representing an Alluxio server.
SERVER_CONFIGURATION_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
 
SERVER_VALUE - Static variable in enum alluxio.grpc.Scope
SERVER = 3;
SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.AddQuorumServerRequest
 
SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.QuorumServerInfo
 
SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.RemoveQuorumServerPRequest
 
SERVERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.TransferLeadershipPRequest
 
serveRequest(S3Handler) - Method in class alluxio.proxy.s3.S3RequestServlet
Core place to call S3 task's core API logic handling function w/o exception handling.
ServerErrorResponseEvent - Class in alluxio.client.file.dora.netty.event
Server error response event.
ServerErrorResponseEvent(AlluxioStatusException) - Constructor for class alluxio.client.file.dora.netty.event.ServerErrorResponseEvent
Server error response event.
SERVERINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetQuorumInfoPResponse
 
SERVERSTATE_FIELD_NUMBER - Static variable in class alluxio.grpc.QuorumServerInfo
 
ServerUserState - Class in alluxio.security.user
Server global instance of the UserState.
service(HttpServletRequest, HttpServletResponse) - Method in class alluxio.proxy.s3.S3RequestServlet
Implementation to serve the HttpServletRequest and returns HttpServletResponse.
SERVICE_NAME - Static variable in class alluxio.grpc.BlockMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.BlockWorkerGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.FileSystemMasterJobServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.JobMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.JobMasterMasterServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.JobMasterWorkerServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.JournalMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.MessagingServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.MetaMasterProxyServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.MetricsMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.RaftJournalServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.SaslAuthenticationServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.ServiceVersionClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
SERVICE_NAME - Static variable in class alluxio.job.ServiceConstants
 
SERVICE_PREFIX - Static variable in class alluxio.master.AlluxioJobMasterRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.AlluxioProxyRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.s3.S3RequestServlet
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
SERVICE_PREFIX - Static variable in class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
SERVICE_VERSION - Static variable in class alluxio.job.ServiceConstants
 
ServiceConstants - Class in alluxio.job
Alluxio job service constants.
ServiceDiscoveryRecipe - Class in alluxio.membership
ServiceDiscoveryRecipe for etcd, to track health status of all registered services.
ServiceDiscoveryRecipe(AlluxioEtcdClient, String) - Constructor for class alluxio.membership.ServiceDiscoveryRecipe
CTOR for ServiceDiscoveryRecipe.
ServiceNotFoundException - Exception in alluxio.exception
Exception used when the service is not provided by the server.
ServiceNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.ServiceNotFoundException
Constructs a new exception with the specified detail message and cause.
ServiceType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.version.ServiceType
SERVICETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetServiceVersionPRequest
 
ServiceUtils - Class in alluxio.master
Utility methods for Alluxio services.
ServiceVersionClientServiceGrpc - Class in alluxio.grpc
 
ServiceVersionClientServiceGrpc.AsyncService - Interface in alluxio.grpc
 
ServiceVersionClientServiceGrpc.ServiceVersionClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service ServiceVersionClientService.
ServiceVersionClientServiceGrpc.ServiceVersionClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service ServiceVersionClientService.
ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service ServiceVersionClientService.
ServiceVersionClientServiceGrpc.ServiceVersionClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service ServiceVersionClientService.
ServiceVersionClientServiceHandler - Class in alluxio.grpc
This class is a gRPC handler that serves Alluxio service versions.
ServiceVersionClientServiceHandler(Set<ServiceType>, Supplier<NodeState>) - Constructor for class alluxio.grpc.ServiceVersionClientServiceHandler
Creates service version handler that allows given services.
ServiceVersionClientServiceImplBase() - Constructor for class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase
 
serving() - Method in class alluxio.master.MasterHealthCheckClient.MasterServingHealthCheck
 
SERVLET_PATH - Static variable in class alluxio.metrics.sink.MetricsServlet
 
SessionCleanable - Interface in alluxio.worker
Interface for classes which track sessions and provide a method to clean any expired sessions.
SessionCleaner - Class in alluxio.worker
SessionCleaner periodically checks if any session have become zombies, removes the zombie session and associated data when necessary.
SessionCleaner(Sessions, SessionCleanable...) - Constructor for class alluxio.worker.SessionCleaner
Creates a new instance of SessionCleaner.
SessionInfo - Class in alluxio
Represents one session in the worker daemon.
SessionInfo(long, int) - Constructor for class alluxio.SessionInfo
Creates a new instance of SessionInfo.
Sessions - Class in alluxio
Sessions represents and manages all sessions contacting a worker.
Sessions() - Constructor for class alluxio.Sessions
Creates a new instance of Sessions.
set(int) - Method in interface alluxio.collections.BitSet
Sets the bit at the specified index to true.
set(int) - Method in class alluxio.collections.BuiltinBitSet
 
set(int, T) - Method in class alluxio.collections.UnmodifiableArrayList
 
set(PropertyKey, Object) - Method in class alluxio.conf.AlluxioProperties
Puts the key value pair specified by users.
set(PropertyKey, Object) - Static method in class alluxio.conf.Configuration
Sets the value for the appropriate key in the Properties.
set(PropertyKey, Object, Source) - Static method in class alluxio.conf.Configuration
Sets the value for the appropriate key in the Properties by source.
set(PropertyKey, Object) - Method in class alluxio.conf.InstancedConfiguration
Sets the value for the appropriate key in the Properties.
set(PropertyKey, String) - Method in class alluxio.conf.InstancedConfiguration
Deprecated.
API to aid property key type transition
set(PropertyKey, Object, Source) - Method in class alluxio.conf.InstancedConfiguration
Sets the value for the appropriate key in the Properties by source.
set(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Creates a User and sets it to the ThreadLocal variable.
set(User) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Sets User to the ThreadLocal variable.
SET_ACL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
SET_ATTRIBUTE - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
SET_ATTRIBUTE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
SET_BLOCKS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
SET_PERMISSION_COMMAND - Static variable in class alluxio.util.ShellUtils
a Unix command to set permission.
setAccessAcl(Acl.AccessControlList) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
setAccessAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList access_acl = 10;
setAccessControlException(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets access control exception.
setAccessMode(Bits) - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.Bits accessMode = 3;
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
setAcl(AlluxioURI, SetAclAction, List<AclEntry>) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.setAcl(AlluxioURI, SetAclAction, List, SetAclPOptions) with default options.
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in interface alluxio.client.file.FileSystem
Sets the ACL for a path.
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Sets the ACL for a path.
setAcl(AccessControlList) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the acl of the file.
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
setAcl(PAcl) - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
setAcl(PAcl.Builder) - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl acl = 27;
setAcl(SetAclPRequest, StreamObserver<SetAclPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Sets ACL for the path.
setAcl(SetAclPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Sets ACL for the path.
setAcl(SetAclPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Sets ACL for the path.
setAcl(SetAclPRequest, StreamObserver<SetAclPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Sets ACL for the path.
SetAcl - Class in alluxio.master.backcompat.ops
Test for setting an ACL.
SetAcl() - Constructor for class alluxio.master.backcompat.ops.SetAcl
 
setAcl(List<AclEntry>) - Method in class alluxio.master.file.contexts.CreatePathContext
Sets an immutable copy of acl as the internal access control list.
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
setAcl(AlluxioURI, SetAclAction, List<AclEntry>, SetAclContext) - Method in interface alluxio.master.file.FileSystemMaster
Sets the ACL for a path.
setAcl(SetAclPRequest, StreamObserver<SetAclPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
setAcl(Supplier<JournalContext>, File.SetAclEntry) - Method in class alluxio.master.file.meta.InodeTree
 
setAcl(List<AclEntry>) - Method in class alluxio.master.file.meta.MutableInode
Sets ACL entries into the internal ACL.
setAcl(Acl.AccessControlList) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional .alluxio.proto.shared.AccessControlList acl = 6;
setAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 15;
setAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 19;
setAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
setAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.shared.AccessControlList acl = 14;
setAcl(AccessControlList) - Method in class alluxio.underfs.options.CreateOptions
Sets an initial acl for the newly created file.
setAcl(AccessControlList) - Method in class alluxio.wire.FileInfo
 
SetAclAction - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.SetAclAction
SetAclContext - Class in alluxio.master.file.contexts
Used to merge and wrap SetAclPOptions.
setAclDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
setAclEntries(String, List<AclEntry>) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.BaseUnderFileSystem
 
setAclEntries(FileSystem, String, List<AclEntry>) - Method in class alluxio.underfs.hdfs.acl.SupportedHdfsAclProvider
 
setAclEntries(FileSystem, String, List<AclEntry>) - Method in interface alluxio.underfs.hdfs.HdfsAclProvider
Sets the ACL and default ACL for an hdfs path using ACL entries.
setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
setAclEntries(FileSystem, String, List<AclEntry>) - Method in class alluxio.underfs.hdfs.NoopHdfsAclProvider
 
setAclEntries(String, List<AclEntry>) - Method in interface alluxio.underfs.UnderFileSystem
Sets the access control list of a file or directory in under file system.
setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
SetAclPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAclPOptions
SetAclPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAclPOptions
SetAclPOptionsOrBuilder - Interface in alluxio.grpc
 
SetAclPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAclPRequest
SetAclPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAclPRequest
SetAclPRequestOrBuilder - Interface in alluxio.grpc
 
SetAclPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAclPResponse
SetAclPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAclPResponse
SetAclPResponseOrBuilder - Interface in alluxio.grpc
 
setAction(SetAclAction) - Method in class alluxio.grpc.SetAclPRequest.Builder
the set action to perform
setAction(File.PSetAclAction) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional .alluxio.proto.journal.PSetAclAction action = 3;
setActionId(String) - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionId = 1;
setActionId(String) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string actionId = 2;
setActionIdBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionId = 1;
setActionIdBytes(ByteString) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string actionId = 2;
setActions(int, PAclAction) - Method in class alluxio.grpc.PAclEntry.Builder
repeated .alluxio.grpc.file.PAclAction actions = 3;
setActions(int, Acl.AclAction) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
repeated .alluxio.proto.shared.AclAction actions = 1;
setActions(int, Acl.AclAction) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
repeated .alluxio.proto.shared.AclAction actions = 3;
setActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
setActions(Acl.AclActions.Builder) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional .alluxio.proto.shared.AclActions actions = 2;
setActions(AclActions) - Method in class alluxio.security.authorization.AclEntry.Builder
Sets a copy of actions for this entry.
setActionsCanceled(long) - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsCanceled = 8;
setActionsFailed(long) - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsFailed = 9;
setActionsRunning(long) - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsRunning = 6;
setActionsScheduled(long) - Method in class alluxio.grpc.PolicyStatus.Builder
metrics
setActionsSucceeded(long) - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 actionsSucceeded = 7;
setActionStatus(String) - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionStatus = 3;
setActionStatusBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionStatus = 3;
setActionType(String) - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionType = 2;
setActionTypeBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
optional string actionType = 2;
setActiveSyncTxId(File.ActiveSyncTxIdEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
setActiveSyncTxId(File.ActiveSyncTxIdEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
action fields.
setAddedBlocks(int, LocationBlockIdListEntry) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
setAddedBlocks(int, LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
setAddMountPoint(File.AddMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
setAddMountPoint(File.AddMountPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddMountPointEntry add_mount_point = 2;
setAddQuorumServerRequest(AddQuorumServerRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
setAddQuorumServerRequest(AddQuorumServerRequest.Builder) - Method in class alluxio.grpc.JournalQueryRequest.Builder
optional .alluxio.grpc.meta.AddQuorumServerRequest addQuorumServerRequest = 3;
setAddress(NetAddress) - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
setAddress(NetAddress.Builder) - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.NetAddress address = 1;
setAddress(WorkerNetAddress) - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
setAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 2;
setAddress(WorkerNetAddress) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
setAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
optional .alluxio.grpc.WorkerNetAddress address = 1;
setAddress(Address) - Method in class alluxio.wire.MasterInfo
 
setAddress(WorkerNetAddress) - Method in class alluxio.wire.WorkerInfo
 
setAddresses(Set<String>) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
setAddresses(int, String) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
setAddresses(NetAddress) - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
setAddresses(NetAddress.Builder) - Method in class alluxio.grpc.MasterVersion.Builder
optional .alluxio.grpc.NetAddress addresses = 1;
setAddSyncPoint(File.AddSyncPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
setAddSyncPoint(File.AddSyncPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AddSyncPointEntry add_sync_point = 32;
setAdvice(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task advice.
setAffectedPaths(int, String) - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
setAlias(String...) - Method in class alluxio.conf.PropertyKey.Builder
 
setAll(boolean) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
optional bool all = 1;
setAllOrNone(AllOrNoneSet) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
setAllOrNone(AllOrNoneSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.AllOrNoneSet all_or_none = 3;
setAllowed(boolean) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional bool allowed = 2;
setAllowed(boolean) - Method in interface alluxio.master.audit.AuditContext
Set to true if the operation associated with this AuditContext is allowed, false otherwise.
setAllowed(boolean) - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
setAllowed(boolean) - Method in class alluxio.master.job.JobMasterAuditContext
 
setAllowed(boolean) - Method in class alluxio.s3.S3AuditContext
 
setAllowedOnStandbyMasters(boolean) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
optional bool allowedOnStandbyMasters = 2;
setAllowExists(boolean) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool allowExists = 2;
setAllowLeader(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool allowLeader = 3;
setAllThroughput(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setAlluxioOnly(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool alluxioOnly = 2;
setAlluxioOnly(boolean) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, this field is about whether to delete in the UFS.
setAlluxioPath(String) - Method in class alluxio.grpc.File.Builder
optional string alluxio_path = 1;
setAlluxioPath(String) - Method in class alluxio.grpc.MountPRequest.Builder
the path of alluxio mount point
setAlluxioPath(String) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
optional string alluxioPath = 1;
setAlluxioPath(String) - Method in class alluxio.grpc.UnmountPRequest.Builder
the path of the alluxio mount point
setAlluxioPath(String) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
the path of alluxio mount point
setAlluxioPath(String) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioPath(String) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioPath(String) - Method in class alluxio.worker.block.CreateBlockOptions
 
setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.File.Builder
optional string alluxio_path = 1;
setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.MountPRequest.Builder
the path of alluxio mount point
setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
optional string alluxioPath = 1;
setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.UnmountPRequest.Builder
the path of the alluxio mount point
setAlluxioPathBytes(ByteString) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
the path of alluxio mount point
setAlluxioPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioPathBytes(ByteString) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
optional string alluxio_path = 1;
setAlluxioVersion(String) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setAlluxioVersion(String) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional string alluxioVersion = 3;
setAlluxioVersionBytes(ByteString) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional string alluxioVersion = 3;
setAlluxioWorkDirectory(String) - Method in class alluxio.master.AbstractLocalAlluxioCluster
Sets Alluxio work directory.
setAsync(boolean) - Method in class alluxio.grpc.CacheRequest.Builder
optional bool async = 6;
setAsyncPersistOptions(ScheduleAsyncPersistencePOptions) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
setAsyncPersistOptions(ScheduleAsyncPersistencePOptions.Builder) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions asyncPersistOptions = 2;
setAsyncPersistRequest(File.AsyncPersistRequestEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
setAsyncPersistRequest(File.AsyncPersistRequestEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.AsyncPersistRequestEntry async_persist_request = 16;
setAsyncRestoreEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setAsyncWriteThreads(int) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setAttribute(SetAttributePRequest) - Method in interface alluxio.client.block.stream.BlockWorkerClient
SetAttribute for a file or dir.
setAttribute(SetAttributePRequest) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
setAttribute(String, SetAttributePOptions) - Method in class alluxio.client.file.dora.DoraCacheClient
Set attributes for a file or dir.
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.DoraCacheFileSystem
 
setAttribute(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.setAttribute(AlluxioURI, SetAttributePOptions) with default options.
setAttribute(AlluxioURI, SetAttributePOptions) - Method in interface alluxio.client.file.FileSystem
Sets any number of a path's attributes, such as TTL and pin status.
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
setAttribute(AlluxioURI, SetAttributePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Sets the file or directory attributes.
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
setAttribute(AlluxioURI, SetAttributePOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
setAttribute(FileSystem, AlluxioURI, SetAttributePOptions) - Static method in class alluxio.fuse.AlluxioFuseUtils
Sets attribute for a file.
setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
Sets file or directory attributes.
setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
Sets file or directory attributes.
setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
Sets file or directory attributes.
setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
Sets file or directory attributes.
setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Sets file or directory attributes.
setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Sets file or directory attributes.
setAttribute(SetAttributePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Sets file or directory attributes.
setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Sets file or directory attributes.
setAttribute(AlluxioURI, SetAttributeContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
setAttribute(AlluxioURI, SetAttributeContext) - Method in interface alluxio.master.file.FileSystemMaster
Sets the file attribute.
setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
setAttribute(String, SetAttributePOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
setAttribute(String, SetAttributePOptions) - Method in interface alluxio.worker.dora.DoraWorker
Set Attributes for a file or dir.
setAttribute(String, SetAttributePOptions) - Method in class alluxio.worker.dora.PagedDoraWorker
Set attribute for this file/dir.
setAttribute(SetAttributePRequest, StreamObserver<SetAttributePResponse>) - Method in class alluxio.worker.grpc.DoraWorkerClientServiceHandler
 
setAttributeClientDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
Defaults for the SetAttribute RPC which should only be used on the client side.
SetAttributeContext - Class in alluxio.master.file.contexts
Used to merge and wrap SetAttributePOptions.
setAttributeDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
SetAttributePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAttributePOptions
SetAttributePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAttributePOptions
SetAttributePOptionsOrBuilder - Interface in alluxio.grpc
 
SetAttributePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAttributePRequest
SetAttributePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAttributePRequest
SetAttributePRequestOrBuilder - Interface in alluxio.grpc
 
SetAttributePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAttributePResponse
SetAttributePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SetAttributePResponse
SetAttributePResponseOrBuilder - Interface in alluxio.grpc
 
setAttributeSingleFile(RpcContext, LockedInodePath, boolean, long, SetAttributeContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
setAuthenticatedUserInfo(AuthenticatedUserInfo) - Method in class alluxio.security.authentication.plain.SaslServerHandlerPlain
 
setAuthenticatedUserInfo(AuthenticatedUserInfo) - Method in interface alluxio.security.authentication.SaslServerHandler
To be called by callbacks to store authenticated user information.
setAuthenticationScheme(ChannelAuthenticationScheme) - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.ChannelAuthenticationScheme authenticationScheme = 4;
setAuthMethod(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Sets the connection authentication method to the ThreadLocal variable.
setAuthType(AuthType) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mAuthType field.
setAuthType(AuthType) - Method in class alluxio.master.job.JobMasterAuditContext
Sets mAuthType field.
setAvgColLen(double) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional double avg_col_len = 2;
setAvgColLen(double) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional double avg_col_len = 2;
setBackupError(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
optional bytes backupError = 6;
setBackupHost(String) - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupHost = 3;
setBackupHostBytes(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupHost = 3;
setBackupId(String) - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupId = 1;
setBackupId(String) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
optional string backupId = 1;
setBackupId(UUID) - Method in class alluxio.wire.BackupStatus
Sets the unique backup id.
setBackupIdBytes(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupId = 1;
setBackupIdBytes(ByteString) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
optional string backupId = 1;
setBackupManager(BackupManager) - Method in class alluxio.master.CoreMasterContext.Builder
 
setBackupState(BackupState) - Method in class alluxio.grpc.BackupPStatus.Builder
optional .alluxio.grpc.meta.BackupState backupState = 2;
setBackupUri(String) - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupUri = 4;
setBackupUri(AlluxioURI) - Method in class alluxio.wire.BackupStatus
Sets the backup uri.
setBackupUriBytes(ByteString) - Method in class alluxio.grpc.BackupPStatus.Builder
optional string backupUri = 4;
setBandwidth(long) - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional int64 bandwidth = 1;
setBandwidth(long) - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional int64 bandwidth = 1;
setBandwidth(long) - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional int64 bandwidth = 1;
setBandwidth(long) - Method in class alluxio.grpc.UfsReadOptions.Builder
optional int64 bandwidth = 3;
setBandwidth(long) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 bandwidth = 4;
setBandwidth(long) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 bandwidth = 3;
setBandwidth(long) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 bandwidth = 4;
setBaseLayout(Layout) - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
setBaseLayout(Layout.Builder) - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.Layout base_layout = 2;
setBaseParameters(BaseParameters) - Method in class alluxio.stress.client.ClientIOSummary
 
setBaseParameters(BaseParameters) - Method in class alluxio.stress.client.ClientIOTaskResult
 
setBaseParameters(BaseParameters) - Method in class alluxio.stress.worker.IOTaskResult
 
setBaseParameters(BaseParameters) - Method in class alluxio.stress.worker.IOTaskSummary
 
setBaseParameters(BaseParameters) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setBatchSize(int) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Batch size for partial listings.
setBinaryStats(BinaryColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
setBinaryStats(BinaryColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BinaryColumnStatsData binary_stats = 5;
setBits(Bits) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.Bits bits = 1;
setBitVectors(String) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional string bit_vectors = 4;
setBitVectors(String) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional string bit_vectors = 4;
setBitVectors(String) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectors(String) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectors(String) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectors(String) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectors(String) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional string bit_vectors = 4;
setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional string bit_vectors = 4;
setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional string bit_vectors = 5;
setBitVectorsBytes(ByteString) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional string bit_vectors = 5;
setBlock(Block) - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
setBlock(Block.Builder) - Method in class alluxio.grpc.BlockStatus.Builder
required .alluxio.grpc.block.Block block = 1;
setBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
setBlockContainerIdGenerator(Block.BlockContainerIdGeneratorEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockContainerIdGeneratorEntry block_container_id_generator = 3;
setBlockCount(long) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
This may not accurate because the worker can add/delete blocks before sending the RegisterWorkerPRequest
setBlockCount(long) - Method in class alluxio.wire.WorkerInfo
 
setBlockCount(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets worker block count.
setBlockId(long) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.grpc.Block.Builder
required int64 block_id = 1;
setBlockId(int, long) - Method in class alluxio.grpc.BlockIdList.Builder
repeated int64 blockId = 1;
setBlockId(long) - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 blockId = 1;
setBlockId(long) - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the block being committed
setBlockId(long) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
the id of the block
setBlockId(long) - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
optional int64 block_id = 1;
setBlockId(long) - Method in class alluxio.wire.BlockInfo
 
setBlockIds(int, long) - Method in class alluxio.grpc.FileInfo.Builder
repeated int64 blockIds = 13;
setBlockIds(int, long) - Method in class alluxio.grpc.PersistFile.Builder
repeated int64 blockIds = 2;
setBlockIds(List<Long>) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setBlockIds(int, long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
setBlockIds(List<Long>) - Method in class alluxio.wire.FileInfo
 
setBlockIds(List<Long>) - Method in class alluxio.wire.PersistFile
Set the block ids.
setBlockInfo(BlockInfo) - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
setBlockInfo(BlockInfo.Builder) - Method in class alluxio.grpc.FileBlockInfo.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
setBlockInfo(BlockInfo) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
setBlockInfo(BlockInfo.Builder) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
optional .alluxio.grpc.BlockInfo blockInfo = 1;
setBlockInfo(Block.BlockInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
setBlockInfo(Block.BlockInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.BlockInfoEntry block_info = 4;
setBlockInfo(BlockInfo) - Method in class alluxio.wire.FileBlockInfo
 
setBlockLocation(BlockLocation) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
setBlockLocation(BlockLocation.Builder) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional .alluxio.grpc.BlockLocation block_location = 3;
setBlockMasterInfo(BlockMasterInfo) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
setBlockMasterInfo(BlockMasterInfo.Builder) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
optional .alluxio.grpc.block.BlockMasterInfo blockMasterInfo = 1;
setBlockReader(BlockReader) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setBlockReader(BlockReader) - Method in class alluxio.worker.netty.BlockReadRequestContext
 
setBlocks(int, Block) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
setBlocks(int, Block.Builder) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
setBlocks(int, long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
setBlocks(int, long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated int64 blocks = 16;
setBlockSize(long) - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 block_size = 3;
setBlockSize(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The block size.
setBlockSize(long) - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
setBlockSizeBytes(long) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the size of the block in bytes.
setBlockSizeBytes(long) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 blockSizeBytes = 1;
setBlockSizeBytes(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 blockSizeBytes = 6;
setBlockSizeBytes(long) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setBlockSizeBytes(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 block_size_bytes = 8;
setBlockSizeBytes(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 block_size_bytes = 2;
setBlockSizeBytes(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
file only
setBlockSizeBytes(long) - Method in class alluxio.wire.FileInfo
 
setBlockSizeBytes(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets block size bytes.
setBlockSizeBytes(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets block size bytes.
setBlockStatus(int, BlockStatus) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
setBlockStatus(int, BlockStatus.Builder) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
setBlockStoreFactory(BlockMetaStore.Factory) - Method in class alluxio.master.CoreMasterContext.Builder
 
setBlockWriter(BlockWriter) - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
setBooleanStats(BooleanColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
setBooleanStats(BooleanColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.BooleanColumnStatsData boolean_stats = 1;
setBooleanType(boolean) - Method in class alluxio.grpc.table.Value.Builder
bool boolean_type = 4;
setBucket(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setBucket(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setBucket(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
 
setBucket(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setBucket(String) - Method in class alluxio.s3.S3AuditContext
Sets mBucket field.
setBucketAndSlot(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
Set the bucket and slot.
setBucketCount(long) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
optional int64 bucket_count = 2;
setBucketedBy(int, String) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
setBucketIndex(int) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
Set the bucket index.
setBucketProperty(HiveBucketProperty) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
setBucketProperty(HiveBucketProperty.Builder) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.HiveBucketProperty bucket_property = 3;
setBuckets(List<ListAllMyBucketsResult.Bucket>) - Method in class alluxio.s3.ListAllMyBucketsResult
 
setBuildVersion(BuildVersion) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
setBuildVersion(BuildVersion.Builder) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
the worker version to display in info pages (useful for rolling upgrades)
setBuildVersion(BuildVersion) - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
setBuildVersion(BuildVersion.Builder) - Method in class alluxio.grpc.WorkerInfo.Builder
optional .alluxio.grpc.BuildVersion buildVersion = 10;
setBuildVersion(BuildVersion) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Sets the build version of the worker.
setBypassDelegation(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool bypassDelegation = 4;
setBytes(long) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
optional int64 bytes = 1;
setBytes(long) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
optional int64 bytes = 1;
setBytesReserved(long) - Method in class alluxio.worker.netty.BlockWriteRequestContext
 
setBytesSkipped(long) - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int64 bytes_skipped = 4;
setCacheable(boolean) - Method in class alluxio.grpc.FileInfo.Builder
optional bool cacheable = 11;
setCacheable(boolean) - Method in class alluxio.master.file.contexts.CreateFileContext
 
setCacheable(boolean) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setCacheable(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool cacheable = 11;
setCacheable(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool cacheable = 5;
setCacheable(boolean) - Method in class alluxio.wire.FileInfo
 
setCacheEnabled(boolean) - Method in class alluxio.client.file.cache.context.CachePerThreadContext
 
setCacheEvictorOptions(CacheEvictorOptions) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setCacheHit(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache hit.
setCacheIdentifier(String) - Method in class alluxio.client.file.CacheContext
 
setCacheMiss(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache miss.
setCacheQuota(CacheQuota) - Method in class alluxio.client.file.CacheContext
 
setCacheScope(CacheScope) - Method in class alluxio.client.file.CacheContext
 
setCacheSize(long) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setCacheSize(long) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 cacheSize = 2;
setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
optional bool cancel = 2;
setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, this request is to cancel the reading request for the id.
setCancel(boolean) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool cancel = 6;
setCancel(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setCancel(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setCancelState(PersistJob.CancelState) - Method in class alluxio.master.file.PersistJob
 
setCancelTaskCommand(CancelTaskCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
setCancelTaskCommand(CancelTaskCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.CancelTaskCommand cancelTaskCommand = 2;
setCandidates(int, Value) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
setCandidates(int, Value.Builder) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
setCanRegisterAgain(boolean) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional bool canRegisterAgain = 3;
setCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
 
setCapacity(Capacity) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets capacity.
setCapacityBytes(long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 capacityBytes = 1;
setCapacityBytes(long) - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 capacityBytes = 5;
setCapacityBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setCapacityBytes(long) - Method in class alluxio.wire.WorkerInfo
 
setCapacityBytes(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets capacity bytes.
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
 
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
 
setChannel(Channel) - Method in class alluxio.network.netty.NettyRPCContext
 
setChannelRef(String) - Method in class alluxio.grpc.SaslMessage.Builder
optional string channelRef = 5;
setChannelRefBytes(ByteString) - Method in class alluxio.grpc.SaslMessage.Builder
optional string channelRef = 5;
setCheckContent(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool check_content = 6;
setCheckContent(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool check_content = 6;
setCheckContent(boolean) - Method in class alluxio.grpc.WriteOptions.Builder
optional bool check_content = 3;
setCheckContent(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool check_content = 11;
setCheckContent(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool check_content = 11;
setCheckS3BucketPath(boolean) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool checkS3BucketPath = 8;
setCheckS3BucketPath(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool checkS3BucketPath = 14;
setCheckUfs(boolean) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
optional bool checkUfs = 1;
setChildCount(long) - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
setChildCount(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 child_count = 26;
setChildren(int, JobInfo) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
setChildren(int, JobInfo.Builder) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
setChunk(Chunk) - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
setChunk(Chunk.Builder) - Method in class alluxio.grpc.ReadResponse.Builder
optional .alluxio.grpc.block.Chunk chunk = 1;
setChunk(ByteString) - Method in class alluxio.grpc.SnapshotData.Builder
optional bytes chunk = 3;
setChunk(Chunk) - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
setChunk(Chunk.Builder) - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.Chunk chunk = 2;
setChunkSize(long) - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 chunk_size = 5;
setChunkSize(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
If set, the server should send packets in the specified packet size.
setClassName(String) - Method in interface alluxio.util.JsonSerializable
 
setClient(AmazonS3) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
setClientId(String) - Method in class alluxio.grpc.SaslMessage.Builder
optional string clientId = 3;
setClientIdBytes(ByteString) - Method in class alluxio.grpc.SaslMessage.Builder
optional string clientId = 3;
setClientMetrics(int, ClientMetrics) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
setClientMetrics(int, ClientMetrics.Builder) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
setClientObserver(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
Sets the client's Sasl stream.
setClientVersion(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
set client version.
setClientVersion(String) - Method in class alluxio.master.job.JobMasterAuditContext
Sets client version.
setClusterConf(AlluxioConfiguration) - Method in class alluxio.ClientContext
 
setClusterConfHash(String) - Method in class alluxio.ClientContext
 
setClusterConfHash(String) - Method in class alluxio.wire.Configuration.Builder
Sets hash of path configurations.
setClusterConfigHash(String) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string clusterConfigHash = 1;
setClusterConfigHash(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string clusterConfigHash = 3;
setClusterConfigHash(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets cluster config hash.
setClusterConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string clusterConfigHash = 1;
setClusterConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string clusterConfigHash = 3;
setClusterConfigLastUpdateTime(long) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 clusterConfigLastUpdateTime = 5;
setClusterConfigLastUpdateTime(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets cluster config last update time.
setClusterConfigs(int, ConfigProperty) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
setClusterConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
setClusterConfLastUpdateTime(long) - Method in class alluxio.wire.Configuration.Builder
Sets cluster config last update time.
setClusterId(String) - Method in class alluxio.grpc.MasterInfo.Builder
optional string clusterId = 11;
setClusterId(String) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
optional string cluster_id = 1;
setClusterId(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets cluster id.
setClusterIdBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
optional string clusterId = 11;
setClusterIdBytes(ByteString) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
optional string cluster_id = 1;
setClusterInfo(Meta.ClusterInfoEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
setClusterInfo(Meta.ClusterInfoEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.ClusterInfoEntry cluster_info = 42;
setClusterName(String) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setCmdConfig(ByteString) - Method in class alluxio.grpc.SubmitRequest.Builder
optional bytes cmdConfig = 1;
setCmdProgress(CmdProgress) - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
setCmdProgress(CmdProgress.Builder) - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.CmdProgress cmdProgress = 8;
setCmdStatus(Status) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
optional .alluxio.grpc.job.Status cmdStatus = 1;
setCmdStatusBlock(CmdStatusBlock) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
setCmdStatusBlock(CmdStatusBlock.Builder) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
optional .alluxio.grpc.job.CmdStatusBlock cmdStatusBlock = 1;
setCode(int) - Method in class alluxio.grpc.BlockStatus.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
setCode(int) - Method in class alluxio.grpc.FileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
setCode(int) - Method in class alluxio.grpc.LoadFileFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
setCode(int) - Method in class alluxio.grpc.RouteFailure.Builder
The status code, which should be an enum value of [google.rpc.Code][google.rpc.Code].
setCode(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setCode(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
Sets the code of this result.
setCode(String) - Method in class alluxio.s3.S3Error
 
setColName(String) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_name = 1;
setColNameBytes(ByteString) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_name = 1;
setColNames(int, String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
setColNames(int, String) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
setCols(int, FieldSchema) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
setCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
setColType(String) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_type = 2;
setColTypeBytes(ByteString) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional string col_type = 2;
setColumnName(String) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required string column_name = 1;
setColumnNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required string column_name = 1;
setCommand(Command) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
setCommand(Command.Builder) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
optional .alluxio.grpc.Command command = 1;
setCommand(FileSystemCommand) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
setCommand(FileSystemCommand.Builder) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
optional .alluxio.grpc.file.FileSystemCommand command = 1;
setCommand(JobMasterMetaCommand) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
optional .alluxio.grpc.job.JobMasterMetaCommand command = 1;
setCommand(MetaCommand) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
optional .alluxio.grpc.meta.MetaCommand command = 1;
setCommand(WriteRequestCommand) - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
setCommand(WriteRequestCommand.Builder) - Method in class alluxio.grpc.WriteRequest.Builder
.alluxio.grpc.block.WriteRequestCommand command = 1;
setCommand(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mCommand field.
setCommand(String) - Method in class alluxio.master.job.JobMasterAuditContext
Sets mCommand field.
setCommand(String) - Method in class alluxio.s3.S3AuditContext
Sets mCommand field.
setCommandOptions(FileSystemCommandOptions) - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
setCommandOptions(FileSystemCommandOptions.Builder) - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.file.FileSystemCommandOptions commandOptions = 2;
setCommandOptions(FileSystemCommandOptions) - Method in class alluxio.wire.FileSystemCommand
Set the command options.
setCommands(int, JobCommand) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
setCommands(int, JobCommand.Builder) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
setCommandType(CommandType) - Method in class alluxio.grpc.Command.Builder
optional .alluxio.grpc.CommandType commandType = 1;
setCommandType(CommandType) - Method in class alluxio.grpc.FileSystemCommand.Builder
optional .alluxio.grpc.CommandType commandType = 1;
setCommandType(CommandType) - Method in class alluxio.wire.FileSystemCommand
Set the command type.
setComment(String) - Method in class alluxio.grpc.table.Database.Builder
optional string comment = 7;
setComment(String) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string comment = 4;
setCommentBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
optional string comment = 7;
setCommentBytes(ByteString) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string comment = 4;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.client.file.options.OutStreamOptions
 
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 5;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.DeletePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.FreePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 2;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.MountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 4;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 3;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.SetAclPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 9;
setCommonOptions(FileSystemMasterCommonPOptions) - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(FileSystemMasterCommonPOptions.Builder) - Method in class alluxio.grpc.UnmountPOptions.Builder
optional .alluxio.grpc.file.FileSystemMasterCommonPOptions commonOptions = 1;
setCommonOptions(Cache.PPageStoreCommonOptions) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
setCommonOptions(Cache.PPageStoreCommonOptions.Builder) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
optional .alluxio.proto.client.PPageStoreCommonOptions commonOptions = 1;
setCompleted(boolean) - Method in class alluxio.grpc.FileInfo.Builder
optional bool completed = 8;
setCompleted(boolean) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setCompleted(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool completed = 10;
setCompleted(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional bool completed = 4;
setCompleted(boolean) - Method in class alluxio.wire.FileInfo
 
setCompleteFile(File.CompleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
setCompleteFile(File.CompleteFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CompleteFileEntry complete_file = 5;
setConfig(JobConfig) - Method in class alluxio.master.job.tracker.CmdRunAttempt
Set job config.
setConfigCheckErrorNum(int) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check error num.
setConfigCheckErrors(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check errors.
setConfigCheckStatus(ConfigStatus) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check status.
setConfigCheckWarnNum(int) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check warn num.
setConfigCheckWarns(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check warns.
setConfigHash(ConfigHash) - Method in class alluxio.wire.MasterWebUIConfiguration
Sets config hash.
setConfigs(int, ConfigProperty) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
setConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
setConfigs(int, ConfigProperty) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
setConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioProxyInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setConfiguration(TreeSet<Triple<String, String, String>>) - Method in class alluxio.wire.MasterWebUIConfiguration
Sets configuration.
setConfiguration(TreeSet<Triple<String, String, String>>) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets configuration.
setConnection(GrpcMessagingConnection) - Method in class alluxio.master.backup.BackupHandshakeMessage
 
setConnectionUser(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Creates a connection User and sets it to the ThreadLocal variable.
setConsistencyCheckLevel(PropertyKey.ConsistencyCheckLevel) - Method in class alluxio.conf.PropertyKey.Builder
 
setConstraint(Constraint) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
setConstraint(Constraint.Builder) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional .alluxio.grpc.table.Constraint constraint = 3;
setContainerHost(String) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string containerHost = 7;
setContainerHost(String) - Method in class alluxio.wire.WorkerNetAddress
 
setContainerHostBytes(ByteString) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string containerHost = 7;
setContainerId(long) - Method in class alluxio.master.file.state.DirectoryId
 
setContainerId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 container_id = 1;
setContentHash(String) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional string contentHash = 4;
setContentHash(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string contentHash = 34;
setContentHash(String) - Method in class alluxio.grpc.UfsFileStatus.Builder
optional string content_hash = 1;
setContentHash(String) - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
setContentHash(String) - Method in class alluxio.wire.FileInfo
 
setContentHash(String) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setContentHashBytes(ByteString) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional string contentHash = 4;
setContentHashBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string contentHash = 34;
setContentHashBytes(ByteString) - Method in class alluxio.grpc.UfsFileStatus.Builder
optional string content_hash = 1;
setContentHashBytes(ByteString) - Method in class alluxio.grpc.WriteResponse.Builder
Errors will be handled by standard gRPC stream APIs.
setContentLength(long) - Method in class alluxio.grpc.UfsFileStatus.Builder
optional int64 content_length = 2;
setContext(GrpcMessagingContext) - Method in class alluxio.master.transport.GrpcMessagingThread
Sets the Grpc messaging context.
setContinuationToken(String) - Method in class alluxio.s3.ListBucketOptions
 
setCopyJob(Job.CopyJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
setCopyJob(Job.CopyJobEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.CopyJobEntry copy_job = 54;
setCount(long) - Method in class alluxio.grpc.StatusSummary.Builder
optional int64 count = 2;
setCounter(Counter) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setCounter(Counter) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setCounter(Counter) - Method in class alluxio.worker.netty.ReadRequestContext
 
setCounter(Counter) - Method in class alluxio.worker.netty.WriteRequestContext
 
setCreateAncestors(boolean) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional bool createAncestors = 2;
setCreatedAt(long) - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 created_at = 3;
setCreatedAt(long) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 created_at = 3;
setCreateOptions(CreateOptions) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
setCreateOptions(CreateOptions) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
setCreateParent(boolean) - Method in class alluxio.underfs.options.CreateOptions
Sets option to force creation of parent directories.
setCreateParent(boolean) - Method in class alluxio.underfs.options.MkdirsOptions
Sets option to create parent directories.
setCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
setCreateUfsFileOptions(Protocol.CreateUfsFileOptions.Builder) - Method in class alluxio.grpc.WriteRequestCommand.Builder
Cancel, close and error will be handled by standard gRPC stream APIs.
setCreateUfsFileOptions(Protocol.CreateUfsFileOptions) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
setCreateUfsFileOptions(Protocol.CreateUfsFileOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for ufs writes.
setCreationDate(String) - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
 
setCreationTimeMs(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 creationTimeMs = 7;
setCreationTimeMs(long) - Method in class alluxio.master.file.meta.MutableInode
 
setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 creation_time_ms = 6;
setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 creation_time_ms = 6;
setCreationTimeMs(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 creation_time_ms = 6;
setCreationTimeMs(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 creation_time_ms = 2;
setCreationTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setCreationTimeNs(long) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mCreationTimeNs field.
setCreationTimeNs(long) - Method in class alluxio.master.job.JobMasterAuditContext
Sets mCreationTimeNs field.
setCreationTimeNs(long) - Method in class alluxio.s3.S3AuditContext
Sets mCreationTimeNs field.
setCurrentBlocks(int, LocationBlockIdListEntry) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
setCurrentBlocks(int, LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
setCurrentContent(ByteBuf) - Method in class alluxio.s3.MultiChunkEncodingInputStream
Sets currentContent with given content.
setCurrentDirectory(UIFileInfo) - Method in class alluxio.wire.MasterWebUIBrowse
Sets current directory.
setCurrentPath(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets current path.
setCurrentPath(String) - Method in class alluxio.wire.MasterWebUILogs
Sets current path.
setCurrentPath(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets current path.
setData(ByteString) - Method in class alluxio.grpc.Chunk.Builder
optional bytes data = 1;
setData(int, long) - Method in class alluxio.grpc.Command.Builder
repeated int64 data = 2;
setData(SnapshotData) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
setData(SnapshotData.Builder) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
setData(ColumnStatisticsData) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
setData(ColumnStatisticsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
optional .alluxio.grpc.table.ColumnStatisticsData data = 3;
setData(SnapshotData) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
setData(SnapshotData.Builder) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
setData(List<WorkerBenchDataPoint>) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
setDatabase(int, String) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
setDatabase(String) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
optional string database = 1;
setDatabaseBytes(ByteString) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
optional string database = 1;
setDataCacheEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
setDataCols(int, FieldSchema) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
setDataCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
setDataPort(int) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 dataPort = 3;
setDataPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setDataReaderActive(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setDateStats(DateColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
setDateStats(DateColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DateColumnStatsData date_stats = 7;
setDaysSinceEpoch(long) - Method in class alluxio.grpc.table.Date.Builder
required int64 days_since_epoch = 1;
setDb(Database) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
setDb(Database.Builder) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
optional .alluxio.grpc.table.Database db = 1;
setDbName(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string db_name = 4;
setDbName(String) - Method in class alluxio.grpc.table.Database.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string db_name = 3;
setDbName(String) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.TableInfo.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string db_name = 1;
setDbName(String) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string db_name = 4;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string db_name = 3;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.TableInfo.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string db_name = 1;
setDbNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string db_name = 1;
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIBrowse
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUILogs
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIMasters
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIMountTable
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIOverview
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIWorkers
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.WorkerWebUIInit
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.WorkerWebUILogs
Sets debug.
setDecimalStats(DecimalColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
setDecimalStats(DecimalColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DecimalColumnStatsData decimal_stats = 6;
setDecommissionedWorkerNum(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 decommissionedWorkerNum = 8;
setDefault(boolean) - Method in class alluxio.security.authorization.AclEntry
Sets the entry to be default.
setDefaultAcl(PAcl) - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
setDefaultAcl(PAcl.Builder) - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.file.PAcl defaultAcl = 28;
setDefaultAcl(List<AclEntry>) - Method in class alluxio.master.file.contexts.CreateDirectoryContext
Sets the default ACL in the context.
setDefaultACL(DefaultAccessControlList) - Method in class alluxio.master.file.meta.MutableInode
 
setDefaultACL(DefaultAccessControlList) - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
setDefaultACL(DefaultAccessControlList) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
setDefaultAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 16;
setDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
setDefaultAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional .alluxio.proto.shared.AccessControlList defaultAcl = 4;
setDefaultAcl(Acl.AccessControlList) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
setDefaultAcl(Acl.AccessControlList.Builder) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.proto.shared.AccessControlList default_acl = 14;
setDefaultAcl(DefaultAccessControlList) - Method in class alluxio.wire.FileInfo
 
setDefaultSupplier(DefaultSupplier) - Method in class alluxio.conf.PropertyKey.Builder
 
setDefaultSupplier(Supplier<Object>, String) - Method in class alluxio.conf.PropertyKey.Builder
 
setDefaultTaskExecutorPoolSize(int) - Method in class alluxio.worker.job.task.TaskExecutorManager
Sets the number of threads in the task executor pool when not throttled.
setDefaultValue(Object) - Method in class alluxio.conf.PropertyKey.Builder
 
setDefinition(String) - Method in class alluxio.grpc.table.Transformation.Builder
optional string definition = 2;
setDefinition(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string definition = 3;
setDefinition(String) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string definition = 3;
setDefinitionBytes(ByteString) - Method in class alluxio.grpc.table.Transformation.Builder
optional string definition = 2;
setDefinitionBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string definition = 3;
setDefinitionBytes(ByteString) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string definition = 3;
setDelay(long) - Method in class alluxio.util.executor.ControllableQueue.DelayNode
Sets the delay.
setDeleteBlock(Block.DeleteBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
setDeleteBlock(Block.DeleteBlockEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteBlockEntry delete_block = 29;
setDeleted(boolean) - Method in class alluxio.master.file.meta.MutableInode
 
setDeleted(List<DeleteObjectsResult.DeletedObject>) - Method in class alluxio.s3.DeleteObjectsResult
Sets the set of deleted objects.
setDeleteFile(File.DeleteFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
setDeleteFile(File.DeleteFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteFileEntry delete_file = 6;
setDeleteMarker(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
Sets the delete marker of this delete result.
setDeleteMarkerVersionId(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
Sets the version id of delete marker.
setDeleteMountPoint(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool deleteMountPoint = 6;
setDeleteMountPoint(File.DeleteMountPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
setDeleteMountPoint(File.DeleteMountPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.DeleteMountPointEntry delete_mount_point = 8;
setDeleteObject(List<DeleteObjectsRequest.DeleteObject>) - Method in class alluxio.s3.DeleteObjectsRequest
Set of items to delete.
setDelimiter(String) - Method in class alluxio.conf.PropertyKey.Builder
 
setDelimiter(String) - Method in class alluxio.s3.ListBucketOptions
 
setDesc(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task name.
setDescription(String) - Method in class alluxio.conf.PropertyKey.Builder
 
setDescription(String) - Method in class alluxio.grpc.JobInfo.Builder
optional string description = 13;
setDescription(String) - Method in class alluxio.grpc.table.Database.Builder
optional string description = 2;
setDescription(String) - Method in class alluxio.job.wire.TaskInfo
 
setDescription(String) - Method in class alluxio.metrics.MetricKey.Builder
 
setDescriptionBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
optional string description = 13;
setDescriptionBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
optional string description = 2;
setDeviceSpec(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setDirectChildrenLoaded(FileSystem, AlluxioURI, boolean) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
Sets direct children loaded.
setDirectChildrenLoaded(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool directChildrenLoaded = 13;
setDirectChildrenLoaded(Supplier<JournalContext>, InodeDirectory) - Method in class alluxio.master.file.meta.InodeTree
Marks an inode directory as having its direct children loaded.
setDirectChildrenLoaded(Supplier<JournalContext>, InodeDirectory, boolean) - Method in class alluxio.master.file.meta.InodeTree
Marks an inode directory as having its direct children loaded or not.
setDirectChildrenLoaded(boolean) - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
setDirectChildrenLoaded(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool direct_children_loaded = 12;
setDirectChildrenLoaded(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool direct_children_loaded = 3;
setDisableAreDescendantsLoadedCheck(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
Setting this to true will disable checking during metadata sync to see if the children of a directory has been loaded.
setDiskCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets disk capacity.
setDiskFreeCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets disk free capacity.
setDiskUsedCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets disk used capacity.
setDisplayType(PropertyKey.DisplayType) - Method in class alluxio.conf.PropertyKey.Builder
 
setDomain(JournalDomain) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
optional .alluxio.grpc.journal.JournalDomain domain = 1;
setDomainSocketPath(String) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string domainSocketPath = 5;
setDomainSocketPath(String) - Method in class alluxio.wire.WorkerNetAddress
 
setDomainSocketPathBytes(ByteString) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string domainSocketPath = 5;
setDoneUnsafe(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setDoneUnsafe(boolean) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setDoneUnsafe(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setDoneUnsafe(boolean) - Method in class alluxio.worker.netty.WriteRequestContext
 
setDoraCacheEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
setDoubleStats(DoubleColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
setDoubleStats(DoubleColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.DoubleColumnStatsData double_stats = 3;
setDoubleType(double) - Method in class alluxio.grpc.table.Value.Builder
double double_type = 2;
setDoubleValue(double) - Method in class alluxio.grpc.MetricValue.Builder
optional double doubleValue = 1;
setDst(String) - Method in class alluxio.grpc.Route.Builder
required string dst = 2;
setDst(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string dst = 2;
setDst(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string dst = 2;
setDstBytes(ByteString) - Method in class alluxio.grpc.Route.Builder
required string dst = 2;
setDstBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string dst = 2;
setDstBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string dst = 2;
setDstPath(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string dstPath = 3;
setDstPath(String) - Method in class alluxio.grpc.RenamePRequest.Builder
the destination path
setDstPath(AlluxioURI) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mDstPath field.
setDstPath(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
Deprecated, use new_parent_id/new_name instead
setDstPathBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string dstPath = 3;
setDstPathBytes(ByteString) - Method in class alluxio.grpc.RenamePRequest.Builder
the destination path
setDstPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
Deprecated, use new_parent_id/new_name instead
setDuration(long) - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 duration = 6;
setDurationMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
setDurationMs(long) - Method in class alluxio.stress.worker.WorkerBenchSummary
 
setEmpty(boolean) - Method in class alluxio.security.authorization.DefaultAccessControlList
 
setEncodingType(String) - Method in class alluxio.s3.ListBucketOptions
 
setEndMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult
 
setEndMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
setEndMs(long) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setEndTime(long) - Method in class alluxio.master.job.AbstractJob
Update end time.
setEndTime(long) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional int64 end_time = 9;
setEndTime(long) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional int64 end_time = 8;
setEndTime(long) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional int64 end_time = 9;
setEndTimeMs(long) - Method in class alluxio.stress.worker.WorkerBenchSummary
 
setEnsureAtomic(boolean) - Method in class alluxio.underfs.options.CreateOptions
Set atomicity guarantees.
setEntityTag(FileSystem, AlluxioURI, String) - Static method in class alluxio.proxy.s3.S3RestUtils
This helper method is used to set the ETag xAttr on an object.
setEntityTag(FileSystem, AlluxioURI, String) - Static method in class alluxio.worker.s3.S3NettyHandler
This helper method is used to set the ETag xAttr on an object.
setEntries(int, PAclEntry) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
setEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
setEntries(int, PAclEntry) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
setEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
setEntries(int, Acl.AclEntry) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
setEntries(int, Acl.AclEntry.Builder) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
setEntry(AclEntry) - Method in class alluxio.security.authorization.AccessControlList
Sets an entry into the access control list.
setEntry(AclEntry) - Method in class alluxio.security.authorization.DefaultAccessControlList
 
setEntry(AclEntry) - Method in class alluxio.security.authorization.ExtendedACLEntries
Sets an entry into the access control list.
setEntryCount(long) - Method in class alluxio.grpc.BackupPStatus.Builder
optional int64 entryCount = 5;
setEntryCount(long) - Method in class alluxio.wire.BackupStatus
Sets entry count.
setEof(boolean) - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
setEof(boolean) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional bool eof = 5;
setEof(boolean) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setEof(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setEquatable(EquatableValueSet) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
setEquatable(EquatableValueSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.EquatableValueSet equatable = 2;
setError(Throwable) - Method in class alluxio.thread.AutopsyThread
Sets the error before exiting.
setError(AlluxioException) - Method in class alluxio.wire.BackupStatus
Fails the backup with given error.
setError(Error) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setError(Error) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setError(Error) - Method in class alluxio.worker.netty.ReadRequestContext
 
setError(Error) - Method in class alluxio.worker.netty.WriteRequestContext
 
setErrored(List<DeleteObjectsResult.ErrorObject>) - Method in class alluxio.s3.DeleteObjectsResult
Sets the set of errored objects in the response.
setErrorMessage(String) - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorMessage = 7;
setErrorMessage(String) - Method in class alluxio.grpc.CmdSummary.Builder
optional string errorMessage = 7;
setErrorMessage(String) - Method in class alluxio.grpc.JobInfo.Builder
optional string errorMessage = 2;
setErrorMessage(String) - Method in class alluxio.job.plan.meta.PlanInfo
 
setErrorMessage(String) - Method in class alluxio.job.wire.TaskInfo
 
setErrorMessageBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorMessage = 7;
setErrorMessageBytes(ByteString) - Method in class alluxio.grpc.CmdSummary.Builder
optional string errorMessage = 7;
setErrorMessageBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
optional string errorMessage = 2;
setErrorMsg(String) - Method in class alluxio.grpc.JobProgress.Builder
optional string errorMsg = 5;
setErrorMsgBytes(ByteString) - Method in class alluxio.grpc.JobProgress.Builder
optional string errorMsg = 5;
setErrors(List<String>) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
setErrors(String, List<String>) - Method in class alluxio.stress.graph.Graph
Sets the list of errors for the series.
setErrors(List<String>) - Method in class alluxio.stress.worker.IOTaskResult
 
setErrors(List<String>) - Method in class alluxio.stress.worker.IOTaskSummary
 
setErrors(List<String>) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setErrorType(String) - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorType = 6;
setErrorType(ErrorType) - Method in class alluxio.grpc.ErrorInfo.Builder
optional .alluxio.grpc.ErrorType errorType = 1;
setErrorType(String) - Method in class alluxio.grpc.JobInfo.Builder
optional string errorType = 15;
setErrorType(String) - Method in class alluxio.grpc.JobProgress.Builder
optional string errorType = 6;
setErrorType(String) - Method in class alluxio.job.plan.meta.PlanInfo
 
setErrorType(String) - Method in class alluxio.job.wire.TaskInfo
 
setErrorTypeBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
optional string errorType = 6;
setErrorTypeBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
optional string errorType = 15;
setErrorTypeBytes(ByteString) - Method in class alluxio.grpc.JobProgress.Builder
optional string errorType = 6;
setETag(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setETag(String) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setEvictBatchSize(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
 
setEvictionAllowed(boolean) - Method in class alluxio.worker.block.AllocateOptions
Sets value for whether eviction is allowed for allocation.
setEvictorClass(Class<? extends CacheEvictor>) - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
 
setExcludeMountInfo(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
Mount info will be excluded from the list status response if this field is set to true.
setExists(boolean) - Method in class alluxio.grpc.ExistsPResponse.Builder
optional bool exists = 1;
setExists(boolean) - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional bool exists = 3;
setExpiryMs(long) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 expiryMs = 3;
setFailedFiles() - Method in class alluxio.cli.fs.command.job.JobAttempt
 
setFailedNodeInfos(NodeInfo[]) - Method in class alluxio.wire.MasterWebUIWorkers
Sets failed node infos.
setFailures(int, RouteFailure) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
setFailures(int, RouteFailure.Builder) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
setFailures(int, LoadFileFailure) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
setFailures(int, LoadFileFailure.Builder) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
setFailures(int, RouteFailure) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
setFailures(int, RouteFailure.Builder) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
setFatalError(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.MasterWebUIData
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.MasterWebUILogs
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets fatal error.
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ActionInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Block.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockIdList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockLocation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BuildVersion.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CacheRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CacheResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Chunk.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClientMetrics.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdProgress.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdSummary.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Command.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigProperties.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigProperty.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ErrorInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.File.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileFailure.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FsOpPId.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobCommand.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobDescription.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobProgress.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobUnused.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterVersion.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Metric.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricValue.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPointInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NetAddress.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PAcl.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PAclEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PersistFile.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PMode.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PolicyInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PolicyStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReadRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReadResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterCommand.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RetryInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Route.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RouteFailure.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SaslMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SnapshotData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StatusSummary.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StorageList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Constraint.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Database.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Date.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Decimal.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Domain.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Layout.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Partition.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Range.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.RangeSet.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Schema.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TableInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Transformation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Value.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TierList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransportMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
setFieldRange(Set<GetWorkerReportOptions.WorkerInfoField>) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
setFieldRanges(int, WorkerInfoField) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
setFile(File) - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
setFile(File.Builder) - Method in class alluxio.grpc.FileFailure.Builder
required .alluxio.grpc.block.File file = 1;
setFileBlockInfos(int, FileBlockInfo) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
setFileBlockInfos(int, FileBlockInfo.Builder) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
setFileBlockInfos(List<FileBlockInfo>) - Method in class alluxio.wire.FileInfo
 
setFileBlocks(List<UIFileBlockInfo>) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file blocks.
setFileBlocksOnTier(List<ImmutablePair<String, List<UIFileBlockInfo>>>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets file blocks on tier.
setFileBuckets(int) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setFileCount(long) - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileCount = 2;
setFileCount(long) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
The total number of files in the listing directory, (i.e.
setFileCount(long) - Method in class alluxio.master.job.tracker.CmdRunAttempt
Set file count.
setFileData(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file data.
setFileData(String) - Method in class alluxio.wire.MasterWebUILogs
Sets file data.
setFileData(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets file data.
setFileDatePattern(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string file_date_pattern = 6;
setFileDatePatternBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string file_date_pattern = 6;
setFileDoesNotExistException(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file does not exist exception.
setFileId(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 fileId = 1;
setFileId(long) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
the id of the file
setFileId(long) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
optional int64 fileId = 1;
setFileId(long) - Method in class alluxio.grpc.PersistFile.Builder
optional int64 fileId = 1;
setFileId(long) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
optional int64 file_id = 1;
setFileId(long) - Method in class alluxio.wire.FileInfo
 
setFileId(long) - Method in class alluxio.wire.PersistFile
Set the file id.
setFileInfo(FileInfo) - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfo(FileInfo.Builder) - Method in class alluxio.grpc.CreateFilePResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfo(FileInfo) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfo(FileInfo.Builder) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfo(FileInfo) - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfo(FileInfo.Builder) - Method in class alluxio.grpc.GetStatusPResponse.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfo(FileInfo) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfo(FileInfo.Builder) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
optional .alluxio.grpc.file.FileInfo fileInfo = 1;
setFileInfos(int, FileInfo) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
setFileInfos(int, FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
setFileInfos(int, FileInfo) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
setFileInfos(int, FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUIData
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUILogs
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.WorkerWebUILogs
Sets file infos.
setFileLength(long) - Method in class alluxio.fuse.file.FileStatus
Sets the length of the file.
setFileLocations(List<String>) - Method in class alluxio.util.webui.UIFileInfo
Sets file locations.
setFilePath(String) - Method in class alluxio.grpc.ActionInfo.Builder
optional string filePath = 4;
setFilePath(String) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string filePath = 3;
setFilePath(String) - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePath = 3;
setFilePath(String) - Method in class alluxio.master.job.tracker.CmdRunAttempt
Set file path.
setFilePathBytes(ByteString) - Method in class alluxio.grpc.ActionInfo.Builder
optional string filePath = 4;
setFilePathBytes(ByteString) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string filePath = 3;
setFilePathBytes(ByteString) - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePath = 3;
setFilePathFailed(String) - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePathFailed = 4;
setFilePathFailedBytes(ByteString) - Method in class alluxio.grpc.JobStatusBlock.Builder
optional string filePathFailed = 4;
setFileSize(long) - Method in class alluxio.grpc.JobProgress.Builder
optional int64 fileSize = 3;
setFileSize(long) - Method in class alluxio.master.job.tracker.CmdRunAttempt
Set file size.
setFilesSkipped(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
optional int32 files_skipped = 3;
setFilesToPersist(List<PersistFile>) - Method in class alluxio.wire.PersistCommandOptions
Set the list of files to persist.
setFileStream(T) - Method in class alluxio.fuse.file.FuseFileEntry
 
setFileSystemOptions(FileSystemOptions) - Method in class alluxio.fuse.options.FuseOptions.Builder
Set file system options.
setFilter(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string filter = 5;
setFilter(int, MasterInfoField) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
setFilter(Job.FileFilter) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
setFilter(Job.FileFilter.Builder) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
setFilter(Job.FileFilter) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
setFilter(Job.FileFilter.Builder) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional .alluxio.proto.journal.FileFilter filter = 12;
setFilterBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string filter = 5;
setFilters(int, BlockMasterInfoField) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
setFirst(T1) - Method in class alluxio.collections.Pair
Set the first value.
setFirst(LockedInodePath) - Method in class alluxio.master.file.meta.InodePathPair
 
setFlush(boolean) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool flush = 5;
setFolder(boolean) - Method in class alluxio.grpc.FileInfo.Builder
optional bool folder = 9;
setFolder(boolean) - Method in class alluxio.wire.FileInfo
 
setForced(boolean) - Method in class alluxio.grpc.FreePOptions.Builder
optional bool forced = 2;
setForceLocation(boolean) - Method in class alluxio.worker.block.AllocateOptions
Sets value for whether to enforce location of allocation.
setForkJoinTaskTag(short) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Atomically sets the tag value for this task and returns the old value.
setFormat(JobProgressReportFormat) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 2;
setFormat(JobProgressReportFormat) - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional .alluxio.grpc.file.JobProgressReportFormat format = 1;
setFreeBytes(long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 freeBytes = 3;
setFreeBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setFreeCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets free capacity.
setFreeCapacityBytes(long) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set free capacity in bytes.
setFromUFSFallBack() - Method in class alluxio.client.file.URIStatus
Sets flag that the FileInfo is retrieved from UFS instead of worker.
setFsType(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setFuseMountOptions(Set<String>) - Method in class alluxio.fuse.options.FuseOptions.Builder
Sets mount options.
setFuseStreamFactory(FuseStreamFactory) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
Set the FuseStreamFactory instance member that is for creating FuseFileStream.
setGainPrimacyTime(String) - Method in class alluxio.wire.MasterInfo
 
setGainPrimacyTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setGcExecutor(ScheduledExecutorService) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGcIntervalMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGroup(String) - Method in class alluxio.client.file.options.OutStreamOptions
 
setGroup(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string group = 17;
setGroup(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string group = 4;
setGroup(String) - Method in class alluxio.grpc.UfsStatus.Builder
optional string group = 5;
setGroup(String) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setGroup(String) - Method in class alluxio.master.file.meta.MutableInode
 
setGroup(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
setGroup(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
setGroup(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
setGroup(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
setGroup(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string group = 10;
setGroup(String) - Method in class alluxio.underfs.options.CreateOptions
 
setGroup(String) - Method in class alluxio.underfs.options.MkdirsOptions
 
setGroup(String) - Method in class alluxio.wire.FileInfo
 
setGroupActions(int, Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
setGroupActions(int, Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
setGroupBits(Bits) - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits groupBits = 2;
setGroupBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets group bits.
setGroupBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string group = 17;
setGroupBytes(ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string group = 4;
setGroupBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
optional string group = 5;
setGroupBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string group = 3;
setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string group = 9;
setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string group = 15;
setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string group = 7;
setGroupBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string group = 10;
setHandler(AbstractHandler) - Method in class alluxio.web.WebServer
 
setHasDirectChildrenLoaded(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool has_direct_children_loaded = 13;
setHigh(Value) - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
setHigh(Value.Builder) - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value high = 2;
setHighestTierAlias(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets highest tier alias.
setHighValue(Date) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
setHighValue(Date.Builder) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date high_value = 2;
setHighValue(Decimal) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
setHighValue(Decimal.Builder) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal high_value = 2;
setHighValue(double) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double high_value = 2;
setHighValue(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 high_value = 2;
setHighWaterMark(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
 
setHiveCacheContext(HiveCacheContext) - Method in class alluxio.client.file.CacheContext
 
setHost(String) - Method in class alluxio.grpc.NetAddress.Builder
optional string host = 1;
setHost(String) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string host = 1;
setHost(String) - Method in class alluxio.wire.Address
 
setHost(String) - Method in class alluxio.wire.WorkerNetAddress
 
setHostBytes(ByteString) - Method in class alluxio.grpc.NetAddress.Builder
optional string host = 1;
setHostBytes(ByteString) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional string host = 1;
setHostname(String) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional string hostname = 4;
setHostname() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Sets hostname.
setHostname(String) - Method in class alluxio.wire.BackupStatus
Sets the backup host.
setHostnameBytes(ByteString) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional string hostname = 4;
setId(long) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.grpc.JobInfo.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.grpc.PolicyInfo.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
optional int64 id = 1;
setId(int) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional uint32 id = 1;
setId(long) - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.grpc.WriteRequestCommand.Builder
The block ID or UFS file ID.
setId(long) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
The block ID or UFS file ID.
setId(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 id = 2;
setId(long) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 id = 1;
setId(long) - Method in class alluxio.wire.MasterInfo
 
setId(long) - Method in class alluxio.wire.WorkerInfo
 
setIdentifier(ByteString) - Method in class alluxio.grpc.WorkerIdentity.Builder
exactly how this byte sequence is interpreted depends on the version of its definition
setIgnoreClusterConf(boolean) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignoreClusterConf = 2;
setIgnoredSiteProperty(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setIgnorePathConf(boolean) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool ignorePathConf = 3;
setIgnoreSyncErrors(boolean) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional bool ignore_sync_errors = 6;
setInAlluxioFileNum(int) - Method in class alluxio.wire.MasterWebUIData
Sets in alluxio file num.
setInAlluxioPercentage(int) - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inAlluxioPercentage = 24;
setInAlluxioPercentage(int) - Method in class alluxio.wire.FileInfo
 
setIncludeRealContentHash(boolean) - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool includeRealContentHash = 5;
setIncludeRealContentHash(boolean) - Method in class alluxio.underfs.options.GetStatusOptions
 
setInconsistentPaths(int, String) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
setIndex(int) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setInfo(int, TransformJobInfo) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
setInfo(int, TransformJobInfo.Builder) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
setInfos(int, ActionInfo) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
setInfos(int, ActionInfo.Builder) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
setInitialBytes(long) - Method in class alluxio.worker.block.CreateBlockOptions
 
setInitialDelayMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setInitiated(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
 
setInMemoryPercentage(int) - Method in class alluxio.grpc.FileInfo.Builder
optional int32 inMemoryPercentage = 25;
setInMemoryPercentage(int) - Method in class alluxio.wire.FileInfo
 
setInodeDirectory(File.InodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
setInodeDirectory(File.InodeDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryEntry inode_directory = 9;
setInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
setInodeDirectoryIdGenerator(File.InodeDirectoryIdGeneratorEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeDirectoryIdGeneratorEntry inode_directory_id_generator = 10;
setInodeFile(File.InodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
setInodeFile(File.InodeFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeFileEntry inode_file = 11;
setInodeLastModificationTime(File.InodeLastModificationTimeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
setInodeLastModificationTime(File.InodeLastModificationTimeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.InodeLastModificationTimeEntry inode_last_modification_time = 12;
setInodeStoreFactory(InodeStore.Factory) - Method in class alluxio.master.CoreMasterContext.Builder
 
setInputFormat(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string input_format = 2;
setInputFormatBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string input_format = 2;
setInstance(String) - Method in class alluxio.grpc.Metric.Builder
optional string instance = 1;
setInstanceBytes(ByteString) - Method in class alluxio.grpc.Metric.Builder
optional string instance = 1;
setInternalAcl(AccessControlList) - Method in class alluxio.master.file.meta.MutableInode
Sets the internal ACL to a specified ACL.
setInterval(int) - Method in class alluxio.util.WaitForOptions
 
setInvalidPathError(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets invalid path error.
setInvalidPathError(String) - Method in class alluxio.wire.MasterWebUILogs
Sets invalid path error.
setInvalidPathError(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets invalid path error.
setInvalidPathError(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets invalid path error.
setInvalidPathException(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets invalid path exception.
setIOBytes(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
setIOBytes(long) - Method in class alluxio.stress.worker.WorkerBenchSummary
 
setIOBytes(long) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setIOMBps(float) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
setIOMBps(float) - Method in class alluxio.stress.worker.WorkerBenchSummary
 
setIp(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mIp field.
setIp(String) - Method in class alluxio.master.job.JobMasterAuditContext
Sets mIp field.
setIp(String) - Method in class alluxio.s3.S3AuditContext
Sets mIp field.
setIsAsyncWriteEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setIsAtomicWrite(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool isAtomicWrite = 16;
setIsBuiltIn(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setIsCacheable(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_cacheable = 17;
setIsClusterAggregated(boolean) - Method in class alluxio.metrics.MetricKey.Builder
 
setIsCompleted(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_completed = 18;
setIsDefault(boolean) - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefault = 5;
setIsDefault(boolean) - Method in class alluxio.grpc.PAclEntry.Builder
optional bool isDefault = 4;
setIsDefault(boolean) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isDefault = 7;
setIsDefault(boolean) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional bool isDefault = 4;
setIsDefault(boolean) - Method in class alluxio.security.authorization.AclEntry.Builder
Set this AclEntry to be for default ACL.
setIsDefaultEmpty(boolean) - Method in class alluxio.grpc.PAcl.Builder
optional bool isDefaultEmpty = 6;
setIsDirectory(boolean) - Method in class alluxio.grpc.UfsStatus.Builder
optional bool is_directory = 2;
setIsDirectory(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_directory = 3;
setIsDynamic(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setIsEmpty(boolean) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional bool isEmpty = 8;
setIsHidden(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setIsLeader(boolean) - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional bool isLeader = 3;
setIsMountPoint(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
directory only
setIsMultipartUpload(boolean) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool isMultipartUpload = 2;
setIsNondeterministic(boolean) - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
 
setIsPinned(boolean) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional bool is_pinned = 9;
setIsRetryable(boolean) - Method in class alluxio.grpc.RetryInfo.Builder
optional bool isRetryable = 1;
setIsScanning(boolean) - Method in class alluxio.grpc.PolicyStatus.Builder
optional bool isScanning = 11;
setIsSkip(boolean) - Method in class alluxio.grpc.RouteFailure.Builder
optional bool is_skip = 5;
setIsThrowable(boolean) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional bool isThrowable = 2;
setIsTruncated(boolean) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
True if the partial listing was truncated.
setIsTruncated(boolean) - Method in class alluxio.proxy.s3.ListPartsResult
 
setJob(Job) - Method in class alluxio.scheduler.job.Task
Set the job.
setJobAsFailed(String, String) - Method in class alluxio.master.job.plan.PlanCoordinator
Sets the job as failed with given error message.
setJobConfig(ByteString) - Method in class alluxio.grpc.RunPRequest.Builder
optional bytes jobConfig = 1;
setJobConfig(ByteString) - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes jobConfig = 3;
setJobConfigAndFileMetrics(List<Pair<String, String>>, boolean, WriteType, CmdRunAttempt) - Method in class alluxio.master.job.tracker.MigrateCliRunner
Create a JobConfig and set file count and size for the Migrate job.
setJobControlId(long) - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional int64 jobControlId = 1;
setJobControlId(long) - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 jobControlId = 1;
setJobControlId(long) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional int64 jobControlId = 1;
setJobControlId(long) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional int64 jobControlId = 1;
setJobControlId(long) - Method in class alluxio.grpc.SubmitResponse.Builder
optional int64 jobControlId = 1;
setJobDescription(JobDescription) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
setJobDescription(JobDescription.Builder) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
setJobDescription(JobDescription) - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
setJobDescription(JobDescription.Builder) - Method in class alluxio.grpc.StopJobPRequest.Builder
required .alluxio.grpc.file.JobDescription jobDescription = 1;
setJobError(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string job_error = 6;
setJobErrorBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string job_error = 6;
setJobId(long) - Method in class alluxio.grpc.CancelPRequest.Builder
optional int64 jobId = 1;
setJobId(long) - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 jobId = 1;
setJobId(long) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional int64 jobId = 1;
setJobId(long) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional int64 jobId = 1;
setJobId(long) - Method in class alluxio.grpc.JobProgress.Builder
optional int64 jobId = 1;
setJobId(long) - Method in class alluxio.grpc.JobStatusBlock.Builder
optional int64 jobId = 1;
setJobId(long) - Method in class alluxio.grpc.RunPResponse.Builder
optional int64 jobId = 1;
setJobId(long) - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 jobId = 1;
setJobId(String) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
optional string jobId = 1;
setJobId(long) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
optional int64 job_id = 1;
setJobId(long) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional int64 job_id = 4;
setJobId(long) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
optional int64 job_id = 1;
setJobId(long) - Method in class alluxio.job.wire.TaskInfo
 
setJobId(long) - Method in class alluxio.master.job.JobMasterAuditContext
Sets mCreationTimeNs field.
setJobId(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string job_id = 8;
setJobId(String) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string job_id = 7;
setJobId(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string job_id = 8;
setJobIdBytes(ByteString) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
optional string jobId = 1;
setJobIdBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string job_id = 8;
setJobIdBytes(ByteString) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string job_id = 7;
setJobIdBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string job_id = 8;
setJobIdOnly(boolean) - Method in class alluxio.grpc.ListAllPOptions.Builder
optional bool jobIdOnly = 3;
setJobIds(int, long) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 1;
setJobInfo(JobInfo) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
setJobInfo(JobInfo.Builder) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
setJobInfo(JobInfo) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
setJobInfo(JobInfo.Builder) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
optional .alluxio.grpc.job.JobInfo jobInfo = 1;
setJobInfos(int, JobInfo) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
setJobInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
setJobMasterId(long) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional int64 jobMasterId = 1;
setJobMasterStatus(int, JobMasterStatus) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
setJobMasterStatus(int, JobMasterStatus.Builder) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
setJobName(String) - Method in class alluxio.master.job.JobMasterAuditContext
Sets mJobName field.
setJobProgress(int, JobProgress) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
setJobProgress(int, JobProgress.Builder) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
setJobSource(JobSource) - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.JobSource jobSource = 3;
setJobState(JobState, boolean) - Method in class alluxio.master.job.AbstractJob
Set load state.
setJobState(JobState, boolean) - Method in interface alluxio.scheduler.job.Job
set job state.
setJobStatus(Status) - Method in class alluxio.grpc.JobStatusBlock.Builder
optional .alluxio.grpc.job.Status jobStatus = 2;
setJobStatus(Status) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional .alluxio.grpc.job.Status job_status = 5;
setJobStatusBlock(int, JobStatusBlock) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
setJobStatusBlock(int, JobStatusBlock.Builder) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
setJobStopped(boolean) - Method in class alluxio.grpc.StopJobPResponse.Builder
optional bool jobStopped = 1;
setJobSuccess() - Method in class alluxio.master.job.CopyJob
 
setJobSuccess() - Method in class alluxio.master.job.DoraLoadJob
 
setJobSuccess() - Method in class alluxio.master.job.LoadJob
 
setJobSuccess() - Method in class alluxio.master.job.MoveJob
 
setJobSuccess() - Method in interface alluxio.scheduler.job.Job
set job as success.
setJobWorkerHealth(JobWorkerHealth) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
setJobWorkerHealth(JobWorkerHealth.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobWorkerHealth jobWorkerHealth = 1;
setJournalCheckpointTimeWarning(String) - Method in class alluxio.wire.MasterWebUIOverview
 
setJournalDiskMetrics(List<JournalDiskInfo>) - Method in class alluxio.wire.MasterWebUIMetrics
 
setJournalDiskWarnings(List<String>) - Method in class alluxio.wire.MasterWebUIOverview
 
setJournalEntries(int, Journal.JournalEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
setJournalEntries(int, Journal.JournalEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 journalEntriesSinceCheckpoint = 2;
setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.master.meta.MasterInfo
 
setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.wire.MasterInfo
 
setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.wire.MasterWebUIMetrics
 
setJournalLastCheckpointTime(String) - Method in class alluxio.wire.MasterWebUIMetrics
 
setJournalSystem(JournalSystem) - Method in class alluxio.master.CoreMasterContext.Builder
 
setKeepAliveClient(CloseableClient) - Method in class alluxio.membership.DefaultServiceEntity
Set keep alive client.
setKey(BlockStoreLocationProto) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
setKey(BlockStoreLocationProto.Builder) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.BlockStoreLocationProto key = 1;
setKey(PropertyKey) - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
setKey(String) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
setKey(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
 
setKey(int) - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest.Part
 
setKey(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setKey(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setKey(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
 
setKey(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setKey(String) - Method in class alluxio.s3.DeleteObjectsRequest.DeleteObject
Sets the key to the object.
setKey(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
Sets the key of successfully deleted object.
setKey(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
Sets the key of error object.
setKeyBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string key = 1;
setKeys(int, String) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
setLastAccessedMs(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_accessed_ms = 30;
setLastAccessTimeMs(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastAccessTimeMs = 31;
setLastAccessTimeMs(long) - Method in class alluxio.master.file.meta.MutableInode
 
setLastAccessTimeMs(long, boolean) - Method in class alluxio.master.file.meta.MutableInode
 
setLastAccessTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_access_time_ms = 20;
setLastAccessTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_access_time_ms = 29;
setLastAccessTimeMs(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_access_time_ms = 18;
setLastAccessTimeMs(long) - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
 
setLastAccessTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setLastCheckpointTime(long) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
optional int64 lastCheckpointTime = 1;
setLastCheckpointTime(String) - Method in class alluxio.wire.MasterInfo
 
setLastCheckpointTimeMs(long) - Method in class alluxio.master.meta.MasterInfo
 
setLastCheckpointTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setLastContactSec(int) - Method in class alluxio.grpc.WorkerInfo.Builder
optional int32 lastContactSec = 3;
setLastContactSec(int) - Method in class alluxio.wire.WorkerInfo
 
setLastHeartbeatTime(long) - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 lastHeartbeatTime = 4;
setLastModificationTimeMs(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 lastModificationTimeMs = 14;
setLastModificationTimeMs(long) - Method in class alluxio.master.file.meta.MutableInode
Sets the last modification time of the inode to the new time if the new time is more recent.
setLastModificationTimeMs(long, boolean) - Method in class alluxio.master.file.meta.MutableInode
 
setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 last_modification_time_ms = 7;
setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 last_modification_time_ms = 7;
setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
optional int64 last_modification_time_ms = 2;
setLastModificationTimeMs(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 last_modification_time_ms = 7;
setLastModificationTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setLastModified(String) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setLastModifiedMs(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 last_modified_ms = 25;
setLastModifiedTimeMs(long) - Method in class alluxio.grpc.UfsStatus.Builder
optional int64 last_modified_time_ms = 3;
setLastUpdated(long) - Method in class alluxio.grpc.JobInfo.Builder
optional int64 lastUpdated = 6;
setLastUpdated(long) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 lastUpdated = 3;
setLastUpdatedTime(long) - Method in class alluxio.grpc.ActionInfo.Builder
optional int64 lastUpdatedTime = 5;
setLastUpdatedTime(String) - Method in class alluxio.wire.MasterInfo
 
setLastUpdatedTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setLastUpdateMs(long) - Method in class alluxio.grpc.JobProgress.Builder
optional int64 lastUpdateMs = 4;
setLatest(SnapshotMetadata) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
setLatest(SnapshotMetadata.Builder) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
setLayout(Layout) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
setLayout(Layout.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Layout layout = 6;
setLayout(Layout) - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
setLayout(Layout.Builder) - Method in class alluxio.grpc.table.Transformation.Builder
optional .alluxio.grpc.table.Layout layout = 1;
setLayoutData(ByteString) - Method in class alluxio.grpc.table.Layout.Builder
optional bytes layout_data = 3;
setLayoutSpec(LayoutSpec) - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
setLayoutSpec(LayoutSpec.Builder) - Method in class alluxio.grpc.table.Layout.Builder
optional .alluxio.grpc.table.LayoutSpec layout_spec = 2;
setLayoutType(String) - Method in class alluxio.grpc.table.Layout.Builder
optional string layout_type = 1;
setLayoutTypeBytes(ByteString) - Method in class alluxio.grpc.table.Layout.Builder
optional string layout_type = 1;
setLeaderId(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets the leader id.
setLeaderMasterAddress(String) - Method in class alluxio.grpc.MasterInfo.Builder
optional string leaderMasterAddress = 1;
setLeaderMasterAddressBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
optional string leaderMasterAddress = 1;
setLease(AlluxioEtcdClient.Lease) - Method in class alluxio.membership.DefaultServiceEntity
Set lease.
setLeaseTimeoutInSec(long) - Method in class alluxio.membership.DefaultServiceEntity
Set the timeout for lease in seconds.
setLeaseTTLInSec(long) - Method in class alluxio.membership.DefaultServiceEntity
Set the TTL for lease in seconds.
setLeastSignificantBits(long) - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 leastSignificantBits = 2;
setLeastSignificantBits(long) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 leastSignificantBits = 2;
setLength(long) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int64 length = 5;
setLength(long) - Method in class alluxio.grpc.Block.Builder
The block length.
setLength(long) - Method in class alluxio.grpc.BlockInfo.Builder
optional int64 length = 2;
setLength(long) - Method in class alluxio.grpc.CacheRequest.Builder
optional int64 length = 5;
setLength(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the length of the block being committed
setLength(long) - Method in class alluxio.grpc.File.Builder
file length
setLength(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 length = 5;
setLength(long) - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 length = 3;
setLength(long) - Method in class alluxio.grpc.Route.Builder
optional int64 length = 3;
setLength(long) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setLength(long) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int64 length = 5;
setLength(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 length = 3;
setLength(long) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
optional int64 length = 2;
setLength(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 length = 3;
setLength(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 length = 9;
setLength(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 length = 2;
setLength(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 length = 3;
setLength(long) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
optional int64 length = 1;
setLength(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 length = 19;
setLength(long) - Method in class alluxio.underfs.options.OpenOptions
 
setLength(long) - Method in class alluxio.wire.BlockInfo
 
setLength(long) - Method in class alluxio.wire.FileInfo
 
setLevel(String) - Method in class alluxio.wire.LogInfo
 
setLFULogBase(double) - Method in class alluxio.client.file.cache.evictor.CacheEvictorOptions
 
setListType(Integer) - Method in class alluxio.s3.ListBucketOptions
 
setLiveWorkerNodes(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets live worker nodes.
setLiveWorkerNum(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 liveWorkerNum = 4;
setLiveWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
 
setLiveWorkers(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set live workers.
setLoadAverage(int, double) - Method in class alluxio.grpc.JobWorkerHealth.Builder
repeated double loadAverage = 2;
setLoadDescendantType(LoadDescendantPType) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.fscommon.LoadDescendantPType loadDescendantType = 3;
setLoadDirectChildren(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
This is deprecated since 1.1.1 and will be removed in 2.0.
setLoadJob(Job.LoadJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
setLoadJob(Job.LoadJobEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.LoadJobEntry load_job = 53;
setLoadMetadataOnly(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
No data will be transferred.
setLoadMetadataOnly(boolean) - Method in class alluxio.grpc.LoadFileRequest.Builder
If set false, only the metadata of file will be loaded.
setLoadMetadataOnly(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool loadMetadataOnly = 4;
setLoadMetadataOnly(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool load_metadata_only = 9;
setLoadMetadataType(LoadMetadataPType) - Method in class alluxio.grpc.ExistsPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
setLoadMetadataType(LoadMetadataPType) - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 1;
setLoadMetadataType(LoadMetadataPType) - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadMetadataType = 2;
setLoadPath(String) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string load_path = 1;
setLoadPathBytes(ByteString) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required string load_path = 1;
setLoadType(LoadMetadataPType) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
optional .alluxio.grpc.file.LoadMetadataPType loadType = 5;
setLocalDirStickyBit(String) - Static method in class alluxio.util.io.FileUtils
Sticky bit can be set primarily on directories in UNIX / Linux.
setLocalFileSystem(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool localFileSystem = 1;
setLocation(String) - Method in class alluxio.grpc.table.Database.Builder
optional string location = 3;
setLocation(String) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional string location = 2;
setLocation(URI) - Method in class alluxio.master.journal.JournalSystem.Builder
 
setLocation(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setLocation(BlockStoreLocation) - Method in class alluxio.worker.block.AllocateOptions
Sets the allocation location.
setLocationBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
optional string location = 3;
setLocationBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional string location = 2;
setLocations(int, BlockLocation) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
setLocations(int, BlockLocation.Builder) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
setLocations(List<BlockLocation>) - Method in class alluxio.wire.BlockInfo
 
setLogLevel(String, String) - Static method in class alluxio.util.LogUtils
Gets a logger's level with specify name, if the level argument is not null, it will set to specify level first.
setLogName(String) - Method in class alluxio.wire.LogInfo
 
setLongestRunning(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
setLongestRunning(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
setLongestRunningJobs(List<JobServiceOutput.SerializableJobInfo>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Set the longest running jobs.
setLongStats(LongColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
setLongStats(LongColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.LongColumnStatsData long_stats = 2;
setLongType(long) - Method in class alluxio.grpc.table.Value.Builder
int64 long_type = 1;
setLosePrimacyTime(String) - Method in class alluxio.wire.MasterInfo
 
setLosePrimacyTimeMs(long) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
setLosePrimacyTimeMs(long) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 losePrimacyTimeMs = 3;
setLosePrimacyTimeMs(long) - Method in class alluxio.master.meta.JobMasterInfo
 
setLosePrimacyTimeMs(long) - Method in class alluxio.master.meta.MasterInfo
 
setLosePrimacyTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setLostMasterInfos(MasterInfo[]) - Method in class alluxio.wire.MasterWebUIMasters
Sets lost master infos.
setLostWorkerNum(int) - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int32 lostWorkerNum = 5;
setLostWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
 
setLostWorkers(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set lost workers.
setLostWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setLow(Value) - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
setLow(Value.Builder) - Method in class alluxio.grpc.table.Range.Builder
optional .alluxio.grpc.table.Value low = 1;
setLowValue(Date) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
setLowValue(Date.Builder) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional .alluxio.grpc.table.Date low_value = 1;
setLowValue(Decimal) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
setLowValue(Decimal.Builder) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional .alluxio.grpc.table.Decimal low_value = 1;
setLowValue(double) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional double low_value = 1;
setLowValue(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 low_value = 1;
setLowWaterMark(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
 
setMarker(String) - Method in class alluxio.s3.ListBucketOptions
 
setMaskActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
setMaskActions(Acl.AclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions maskActions = 5;
setMasterAddress(String) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set master address.
setMasterAddress(NetAddress) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
setMasterAddress(NetAddress.Builder) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
setMasterAddress(NetAddress) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
setMasterAddress(NetAddress.Builder) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.NetAddress masterAddress = 1;
setMasterAddress(NetAddress) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
setMasterAddress(NetAddress.Builder) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.NetAddress masterAddress = 2;
setMasterAddresses(int, NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
setMasterAddresses(int, NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
setMasterCapacityFreePercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master capacity free percentage.
setMasterCapacityUsedPercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master capacity used percentage.
setMasterHostname(String) - Method in class alluxio.grpc.CheckpointPResponse.Builder
The hostname of the master that did the checkpoint
setMasterHostname(String) - Method in class alluxio.wire.WorkerWebUIInit
Sets master ip.
setMasterHostnameBytes(ByteString) - Method in class alluxio.grpc.CheckpointPResponse.Builder
The hostname of the master that did the checkpoint
setMasterId(long) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
optional int64 masterId = 1;
setMasterId(long) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
optional int64 masterId = 1;
setMasterId(long) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
setMasterId(long) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional int64 masterId = 1;
setMasterId(long) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional int64 masterId = 1;
setMasterInfo(MasterInfo) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
setMasterInfo(MasterInfo.Builder) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
optional .alluxio.grpc.meta.MasterInfo masterInfo = 1;
setMasterInquireClient(MasterInquireClient) - Method in class alluxio.master.MasterClientContextBuilder
Set the MasterInquireClient that the config will use.
setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets master node address.
setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIData
Sets master node address.
setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets master node address.
setMasterPort(int) - Method in class alluxio.wire.WorkerWebUIInit
Sets master port.
setMasterProperties(Map<Integer, Map<PropertyKey, String>>) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
Sets master specific properties.
setMasterRole(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets the master role name.
setMasterStatus(List<JobServiceOutput.SerializableJobMasterStatus>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Set master status.
setMasterUnderfsCapacityFreePercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master underfs capacity free percentage.
setMasterUnderfsCapacityUsedPercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master underfs capacity used percentage.
setMasterVersions(List<SummaryOutput.SerializableMasterVersion>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set master versions.
setMasterVersions(int, MasterVersion) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
setMasterVersions(int, MasterVersion.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
setMaxCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setMaxColLen(long) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 max_col_len = 1;
setMaxColLen(long) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 max_col_len = 1;
setMaxEvictionRetries(int) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setMaxKeys(int) - Method in class alluxio.s3.ListBucketOptions
 
setMaxSize(int) - Method in class alluxio.master.metastore.caching.CacheConfiguration.Builder
 
setMaxUfsReadConcurrency(int) - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional int32 maxUfsReadConcurrency = 2;
setMaxUfsReadConcurrency(int) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int32 maxUfsReadConcurrency = 4;
setMedium(String) - Method in class alluxio.worker.block.CreateBlockOptions
 
setMediumType(String) - Method in class alluxio.client.file.options.OutStreamOptions
Set the write medium type of the file.
setMediumType(String) - Method in class alluxio.grpc.BlockLocation.Builder
optional string mediumType = 4;
setMediumType(String) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string mediumType = 2;
setMediumType(String) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional string mediumType = 7;
setMediumType(int, String) - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
setMediumType(String) - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional string medium_type = 2;
setMediumType(String) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional string medium_type = 8;
setMediumType(int, String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
setMediumType(int, String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
setMediumType(int, String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
setMediumType(String) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string mediumType = 3;
setMediumType(int, String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
setMediumType(String) - Method in class alluxio.wire.BlockLocation
 
setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.BlockLocation.Builder
optional string mediumType = 4;
setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string mediumType = 2;
setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional string mediumType = 7;
setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.MoveBlockRequest.Builder
optional string medium_type = 2;
setMediumTypeBytes(ByteString) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional string medium_type = 8;
setMediumTypeBytes(ByteString) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string mediumType = 3;
setMediumTypes(ImmutableSet<String>) - Method in class alluxio.master.file.meta.MutableInode
 
setMediumTypes(Set<String>) - Method in class alluxio.wire.FileInfo
 
setMessage(String) - Method in class alluxio.grpc.BlockStatus.Builder
A developer-facing error message
setMessage(String) - Method in class alluxio.grpc.FileFailure.Builder
A developer-facing error message
setMessage(String) - Method in class alluxio.grpc.LoadFileFailure.Builder
A developer-facing error message
setMessage(String) - Method in class alluxio.grpc.RouteFailure.Builder
A developer-facing error message
setMessage(ByteString) - Method in class alluxio.grpc.SaslMessage.Builder
optional bytes message = 2;
setMessage(ByteString) - Method in class alluxio.grpc.TransportMessage.Builder
optional bytes message = 3;
setMessage(String) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
setMessage(String) - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
setMessage(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
Sets the error message of this result.
setMessage(String) - Method in class alluxio.s3.S3Error
 
setMessage(String) - Method in class alluxio.wire.LogInfo
 
setMessageBytes(ByteString) - Method in class alluxio.grpc.BlockStatus.Builder
A developer-facing error message
setMessageBytes(ByteString) - Method in class alluxio.grpc.FileFailure.Builder
A developer-facing error message
setMessageBytes(ByteString) - Method in class alluxio.grpc.LoadFileFailure.Builder
A developer-facing error message
setMessageBytes(ByteString) - Method in class alluxio.grpc.RouteFailure.Builder
A developer-facing error message
setMessageBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional string message = 2;
setMessageCompression(boolean) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
setMessageType(SaslMessageType) - Method in class alluxio.grpc.SaslMessage.Builder
optional .alluxio.grpc.sasl.SaslMessageType messageType = 1;
setMetadataCacheEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.CompleteFileContext
 
setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.DeleteContext
 
setMetadataLoad(boolean) - Method in class alluxio.master.file.contexts.SetAttributeContext
 
setMeter(Meter) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setMeter(Meter) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setMetrics(int, Metric) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
setMetrics(int, Metric.Builder) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
setMetrics(int, Metric) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
setMetrics(int, Metric.Builder) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setMetricsInfo(List<MetricsOutput.SerializableMetricInfo>) - Method in class alluxio.cli.fsadmin.report.MetricsOutput
Set metrics info.
setMetricType(MetricType) - Method in class alluxio.grpc.Metric.Builder
required .alluxio.grpc.MetricType metricType = 5;
setMetricType(MetricType) - Method in class alluxio.grpc.MetricValue.Builder
optional .alluxio.grpc.MetricType metricType = 6;
setMetricType(MetricType) - Method in class alluxio.metrics.MetricKey.Builder
 
setMinCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setMode(Mode) - Method in class alluxio.client.file.options.OutStreamOptions
 
setMode(String, short) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
setMode(PMode) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
setMode(PMode.Builder) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
setMode(PMode) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
setMode(PMode.Builder) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.PMode mode = 3;
setMode(int) - Method in class alluxio.grpc.FileInfo.Builder
optional int32 mode = 18;
setMode(int) - Method in class alluxio.grpc.PAcl.Builder
optional int32 mode = 4;
setMode(PMode) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
setMode(PMode.Builder) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.grpc.PMode mode = 5;
setMode(int) - Method in class alluxio.grpc.UfsStatus.Builder
optional int32 mode = 6;
setMode(short) - Method in class alluxio.master.file.meta.MutableInode
 
setMode(int) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int32 mode = 4;
setMode(int) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int32 mode = 10;
setMode(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 mode = 16;
setMode(int) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int32 mode = 11;
setMode(short) - Method in class alluxio.security.authorization.AccessControlList
Sets permitted actions for owning user, owning group, and other based on the mode.
setMode(String, short) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
setMode(Mode) - Method in class alluxio.underfs.options.CreateOptions
 
setMode(Mode) - Method in class alluxio.underfs.options.MkdirsOptions
 
setMode(String, short) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
setMode(String, short) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
setMode(String, short) - Method in interface alluxio.underfs.UnderFileSystem
Changes posix file mode.
setMode(String, short) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setMode(int) - Method in class alluxio.wire.FileInfo
 
setMostSignificantBits(long) - Method in class alluxio.grpc.FsOpPId.Builder
optional int64 mostSignificantBits = 1;
setMostSignificantBits(long) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
optional int64 mostSignificantBits = 1;
setMountId(long) - Method in class alluxio.client.file.options.OutStreamOptions
 
setMountId(long) - Method in class alluxio.grpc.Block.Builder
optional int64 mountId = 5;
setMountId(long) - Method in class alluxio.grpc.File.Builder
optional int64 mountId = 4;
setMountId(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 mountId = 23;
setMountId(long) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
required int64 mountId = 1;
setMountId(long) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
the id of the ufs
setMountId(long) - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 mountId = 8;
setMountId(long) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional int64 mount_id = 5;
setMountId(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional int64 mountId = 5;
setMountId(long) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 mount_id = 1;
setMountId(long) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional int64 mount_id = 6;
setMountId(long) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional int64 mount_id = 2;
setMountId(long) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional int64 mount_id = 2;
setMountId(long) - Method in class alluxio.wire.FileInfo
 
setMountId(long) - Method in class alluxio.wire.MountPointInfo
 
setMountOptions(MountPOptions) - Method in class alluxio.wire.UfsInfo
 
setMountPoint(boolean) - Method in class alluxio.grpc.FileInfo.Builder
optional bool mountPoint = 20;
setMountPoint(boolean) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setMountPoint(boolean) - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
setMountPoint(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool mount_point = 11;
setMountPoint(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
optional bool mount_point = 2;
setMountPoint(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setMountPoint(boolean) - Method in class alluxio.wire.FileInfo
 
setMountPointInfos(Map<String, MountPointInfo>) - Method in class alluxio.wire.MasterWebUIMountTable
Sets mount point infos.
setMountPoints(Map<String, MountPointInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setMoveJob(Job.MoveJobEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
setMoveJob(Job.MoveJobEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.MoveJobEntry move_job = 55;
setMsg(String) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
optional string msg = 1;
setMsgBytes(ByteString) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
optional string msg = 1;
setMultipartUploadEnabled(boolean) - Method in class alluxio.underfs.options.CreateOptions
 
setMyRunningWorker(WorkerInfo) - Method in class alluxio.scheduler.job.Task
Set the worker info this task runs on.
setName(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task name.
setName(String) - Method in class alluxio.conf.PropertyKey.Builder
 
setName(String) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string name = 1;
setName(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string name = 2;
setName(String) - Method in class alluxio.grpc.InconsistentProperty.Builder
optional string name = 1;
setName(String) - Method in class alluxio.grpc.JobInfo.Builder
Some jobs don't have these
setName(String) - Method in class alluxio.grpc.ListAllPOptions.Builder
optional string name = 2;
setName(String) - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
setName(String) - Method in class alluxio.grpc.PolicyInfo.Builder
optional string name = 2;
setName(String) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
setName(String) - Method in class alluxio.grpc.UfsStatus.Builder
optional string name = 1;
setName(String) - Method in class alluxio.master.file.meta.MutableInode
 
setName(String) - Method in class alluxio.metrics.MetricKey.Builder
 
setName(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
setName(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
setName(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string name = 3;
setName(String) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string name = 1;
setName(String) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional string name = 2;
setName(String) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
optional string name = 1;
setName(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string name = 6;
setName(String) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional string name = 1;
setName(String) - Method in class alluxio.s3.ListAllMyBucketsResult.Bucket
 
setName(String) - Method in class alluxio.underfs.UfsStatus
Set the name of file or directory.
setName(String) - Method in class alluxio.wire.FileInfo
 
setName(String) - Method in class alluxio.wire.InconsistentProperty
 
setNameBytes(ByteString) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string name = 1;
setNameBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string name = 2;
setNameBytes(ByteString) - Method in class alluxio.grpc.InconsistentProperty.Builder
optional string name = 1;
setNameBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
Some jobs don't have these
setNameBytes(ByteString) - Method in class alluxio.grpc.ListAllPOptions.Builder
optional string name = 2;
setNameBytes(ByteString) - Method in class alluxio.grpc.Metric.Builder
optional string name = 3;
setNameBytes(ByteString) - Method in class alluxio.grpc.PolicyInfo.Builder
optional string name = 2;
setNameBytes(ByteString) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string name = 2;
setNameBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
optional string name = 1;
setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string name = 3;
setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string name = 3;
setNameBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string name = 3;
setNameBytes(ByteString) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string name = 1;
setNameBytes(ByteString) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional string name = 2;
setNameBytes(ByteString) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
optional string name = 1;
setNameBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string name = 6;
setNameBytes(ByteString) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
optional string name = 1;
setNettyDataPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setNetworkGroup(GrpcNetworkGroup) - Method in class alluxio.grpc.GrpcChannelBuilder
Sets the pooling strategy.
setNewBlock(File.NewBlockEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
setNewBlock(File.NewBlockEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.NewBlockEntry new_block = 38;
setNewerVersionAvailable(boolean) - Method in class alluxio.master.meta.DefaultMetaMaster
 
setNewerVersionAvailable(boolean) - Method in interface alluxio.master.meta.MetaMaster
Sets whether newer version Alluxio is available.
setNewerVersionAvailable(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets newer version available.
setNewName(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_name = 5;
setNewNameBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_name = 5;
setNewParentId(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 new_parent_id = 4;
setNewPath(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_path = 7;
setNewPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string new_path = 7;
setNextContainerId(long) - Method in class alluxio.master.block.BlockContainerIdGenerator
 
setNextContainerId(long) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
optional int64 next_container_id = 1;
setNextSequenceNumber(long) - Method in class alluxio.master.journal.options.JournalReaderOptions
 
setNextSequenceNumber(long) - Method in class alluxio.master.journal.options.JournalWriterOptions
 
setNoCache(boolean) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
If set, do not try to cache the block locally when reading the data from the UFS.
setNodeResults(Map<String, T>) - Method in class alluxio.stress.common.GeneralBenchSummary
 
setNodeState(NodeState) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
optional .alluxio.grpc.journal.NodeState node_state = 1;
setNoFormat(boolean) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setNormalNodeInfos(NodeInfo[]) - Method in class alluxio.wire.MasterWebUIWorkers
Sets normal node infos.
setNTotalFile(int) - Method in class alluxio.wire.MasterWebUIBrowse
Sets n total file.
setNTotalFile(int) - Method in class alluxio.wire.MasterWebUILogs
Sets n total file.
setNTotalFile(int) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets n total file.
setNTotalFile(int) - Method in class alluxio.wire.WorkerWebUILogs
Sets n total file.
setNumActiveTasks(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 numActiveTasks = 6;
setNumDistincts(long) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_distincts = 4;
setNumDistincts(long) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_distincts = 4;
setNumDistincts(long) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_distincts = 4;
setNumDistincts(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_distincts = 4;
setNumDistincts(long) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_distincts = 4;
setNumFalses(long) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_falses = 2;
setNumMasters(int) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setNumNulls(long) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
optional int64 num_nulls = 3;
setNumNulls(long) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_nulls = 3;
setNumNulls(long) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
optional int64 num_nulls = 3;
setNumNulls(long) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
optional int64 num_nulls = 3;
setNumNulls(long) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
optional int64 num_nulls = 3;
setNumNulls(long) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
optional int64 num_nulls = 3;
setNumNulls(long) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
optional int64 num_nulls = 3;
setNumOfCandidate(int) - Method in class alluxio.client.file.cache.evictor.NondeterministicLRUCacheEvictor
 
setNumTrues(long) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
optional int64 num_trues = 1;
setNumWorkers(int) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
setObject(String) - Method in class alluxio.s3.S3AuditContext
Sets mObject field.
setOffset(long) - Method in class alluxio.grpc.FileBlockInfo.Builder
optional int64 offset = 2;
setOffset(long) - Method in class alluxio.grpc.ReadRequest.Builder
optional int64 offset = 2;
setOffset(long) - Method in class alluxio.grpc.SnapshotData.Builder
Deprecated. 
setOffset(long) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 offset = 3;
setOffset(long) - Method in class alluxio.grpc.WriteResponse.Builder
optional int64 offset = 1;
setOffset(long) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
optional int64 offset = 2;
setOffset(long) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional int64 offset = 3;
setOffset(long) - Method in class alluxio.underfs.options.FileLocationOptions
Sets the offset for which locations are to be queried.
setOffset(long) - Method in class alluxio.underfs.options.OpenOptions
Sets the offset from the start of a file to be opened for reading.
setOffset(long) - Method in class alluxio.wire.FileBlockInfo
 
setOffsetCount(int) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only start listing items after this many items have been processed.
setOffsetId(long) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start listing after the given FileId, the FileId can be calculated from the result of a previous listing's FileInfo or URIStatus results using the getFileId method.
setOffsetInFile(long) - Method in class alluxio.grpc.Block.Builder
The offset of the block in within ufs the file.
setOffsetInFile(long) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The offset of the block in within the file.
setOffsetReceived(long) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated. 
setOffsetReceived(long) - Method in class alluxio.grpc.ReadRequest.Builder
Read receipt
setOffsetReceived(long) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated. 
setOnlyReserveSpace(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
If set, only reserve space for the block.
setOnReadyHandler(Runnable) - Method in class alluxio.worker.grpc.DataMessageServerStreamObserver
 
setOpenOrCreateFlags(int) - Method in class alluxio.fuse.file.FuseFileEntry
 
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.grpc.CacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.grpc.ReadRequest.Builder
This is only set for UFS block read.
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional .alluxio.proto.dataserver.OpenUfsBlockOptions open_ufs_block_options = 4;
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
setOpenUfsBlockOptions(Protocol.OpenUfsBlockOptions.Builder) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
This is only set for UFS block read.
setOperation(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string operation = 1;
setOperationBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string operation = 1;
setOperationCount(long) - Method in class alluxio.wire.WorkerWebUIOperations
Sets the operation count.
setOperationId(FsOpPId) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
setOperationId(FsOpPId.Builder) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.file.FsOpPId operationId = 4;
setOperationId(Journal.JournalOpPId) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
setOperationId(Journal.JournalOpPId.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.JournalOpPId operationId = 52;
setOperationMetrics(Map<String, Metric>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets operation metrics.
setOperationMetrics(Map<String, Metric>) - Method in class alluxio.wire.WorkerWebUIMetrics
Sets operation metrics.
setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.CompleteFileContext
Sets operation time.
setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.RenameContext
Sets operation time.
setOperationTimeMs(long) - Method in class alluxio.master.file.contexts.SetAttributeContext
Sets operation time.
setOperationType(OperationType) - Method in class alluxio.grpc.CmdStatusBlock.Builder
optional .alluxio.grpc.job.OperationType operationType = 3;
setOperationType(OperationType) - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.OperationType operationType = 2;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional int64 op_time_ms = 4;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional int64 op_time_ms = 3;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
optional int64 op_time_ms = 3;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional int64 op_time_ms = 3;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional int64 op_time_ms = 2;
setOpTimeMs(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 op_time_ms = 2;
setOptions(AddPolicyPOptions) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
setOptions(AddPolicyPOptions.Builder) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 2;
setOptions(BackupPOptions) - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
setOptions(BackupPOptions.Builder) - Method in class alluxio.grpc.BackupPRequest.Builder
optional .alluxio.grpc.meta.BackupPOptions options = 1;
setOptions(BlockHeartbeatPOptions) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
setOptions(BlockHeartbeatPOptions.Builder) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
optional .alluxio.grpc.block.BlockHeartbeatPOptions options = 5;
setOptions(CancelPOptions) - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
setOptions(CancelPOptions.Builder) - Method in class alluxio.grpc.CancelPRequest.Builder
optional .alluxio.grpc.job.CancelPOptions options = 2;
setOptions(CheckAccessPOptions) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
setOptions(CheckAccessPOptions.Builder) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional .alluxio.grpc.file.CheckAccessPOptions options = 2;
setOptions(CheckConsistencyPOptions) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
setOptions(CheckConsistencyPOptions.Builder) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
optional .alluxio.grpc.file.CheckConsistencyPOptions options = 2;
setOptions(CommitBlockPOptions) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
setOptions(CommitBlockPOptions.Builder) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
optional .alluxio.grpc.block.CommitBlockPOptions options = 6;
setOptions(CompleteFilePOptions) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
setOptions(CompleteFilePOptions.Builder) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional .alluxio.grpc.file.CompleteFilePOptions options = 2;
setOptions(CreateDirectoryPOptions) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
setOptions(CreateDirectoryPOptions.Builder) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
optional .alluxio.grpc.file.CreateDirectoryPOptions options = 2;
setOptions(CreateFilePOptions) - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
setOptions(CreateFilePOptions.Builder) - Method in class alluxio.grpc.CreateFilePRequest.Builder
optional .alluxio.grpc.file.CreateFilePOptions options = 2;
setOptions(DeletePOptions) - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
setOptions(DeletePOptions.Builder) - Method in class alluxio.grpc.DeletePRequest.Builder
optional .alluxio.grpc.file.DeletePOptions options = 2;
setOptions(ExistsPOptions) - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
setOptions(ExistsPOptions.Builder) - Method in class alluxio.grpc.ExistsPRequest.Builder
optional .alluxio.grpc.file.ExistsPOptions options = 2;
setOptions(FileSystemHeartbeatPOptions) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
setOptions(FileSystemHeartbeatPOptions.Builder) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
optional .alluxio.grpc.file.FileSystemHeartbeatPOptions options = 3;
setOptions(FreePOptions) - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
setOptions(FreePOptions.Builder) - Method in class alluxio.grpc.FreePRequest.Builder
optional .alluxio.grpc.file.FreePOptions options = 2;
setOptions(GetPolicyStatusPOptions) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
setOptions(GetPolicyStatusPOptions.Builder) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 4;
setOptions(GetAllMasterStatusPOptions) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
setOptions(GetAllMasterStatusPOptions.Builder) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
optional .alluxio.grpc.job.GetAllMasterStatusPOptions options = 1;
setOptions(GetAllWorkerHealthPOptions) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
setOptions(GetAllWorkerHealthPOptions.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
optional .alluxio.grpc.job.GetAllWorkerHealthPOptions options = 1;
setOptions(GetBlockInfoPOptions) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
setOptions(GetBlockInfoPOptions.Builder) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
optional .alluxio.grpc.block.GetBlockInfoPOptions options = 2;
setOptions(GetCmdStatusOptions) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
setOptions(GetCmdStatusOptions.Builder) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
setOptions(GetCmdStatusOptions) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
setOptions(GetCmdStatusOptions.Builder) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
optional .alluxio.grpc.job.GetCmdStatusOptions options = 2;
setOptions(GetFileInfoPOptions) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
setOptions(GetFileInfoPOptions.Builder) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
optional .alluxio.grpc.file.GetFileInfoPOptions options = 2;
setOptions(GetJobMasterIdPOptions) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
setOptions(GetJobMasterIdPOptions.Builder) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
optional .alluxio.grpc.job.GetJobMasterIdPOptions options = 2;
setOptions(JobProgressPOptions) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
setOptions(JobProgressPOptions.Builder) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
optional .alluxio.grpc.file.JobProgressPOptions options = 2;
setOptions(GetJobServiceSummaryPOptions) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
setOptions(GetJobServiceSummaryPOptions.Builder) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
optional .alluxio.grpc.job.GetJobServiceSummaryPOptions options = 1;
setOptions(GetJobStatusDetailedPOptions) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
setOptions(GetJobStatusDetailedPOptions.Builder) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusDetailedPOptions options = 2;
setOptions(GetJobStatusPOptions) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
setOptions(GetJobStatusPOptions.Builder) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
optional .alluxio.grpc.job.GetJobStatusPOptions options = 2;
setOptions(GetMasterIdPOptions) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
setOptions(GetMasterIdPOptions.Builder) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
optional .alluxio.grpc.meta.GetMasterIdPOptions options = 2;
setOptions(GetNewBlockIdForFilePOptions) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
setOptions(GetNewBlockIdForFilePOptions.Builder) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
optional .alluxio.grpc.file.GetNewBlockIdForFilePOptions options = 2;
setOptions(GetPinnedFileIdsPOptions) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
setOptions(GetPinnedFileIdsPOptions.Builder) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
optional .alluxio.grpc.file.GetPinnedFileIdsPOptions options = 1;
setOptions(GetPolicyStatusPOptions) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
setOptions(GetPolicyStatusPOptions.Builder) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional .alluxio.grpc.policy.GetPolicyStatusPOptions options = 2;
setOptions(GetQuorumInfoPOptions) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
setOptions(GetQuorumInfoPOptions.Builder) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
optional .alluxio.grpc.journal.GetQuorumInfoPOptions options = 1;
setOptions(GetRegisterLeasePOptions) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
setOptions(GetRegisterLeasePOptions.Builder) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional .alluxio.grpc.block.GetRegisterLeasePOptions options = 4;
setOptions(GetStateLockHoldersPOptions) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
setOptions(GetStateLockHoldersPOptions.Builder) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
optional .alluxio.grpc.file.GetStateLockHoldersPOptions options = 1;
setOptions(GetStatusPOptions) - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
setOptions(GetStatusPOptions.Builder) - Method in class alluxio.grpc.GetStatusPRequest.Builder
optional .alluxio.grpc.file.GetStatusPOptions options = 2;
setOptions(GetUfsInfoPOptions) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
setOptions(GetUfsInfoPOptions.Builder) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
optional .alluxio.grpc.file.GetUfsInfoPOptions options = 2;
setOptions(GetWorkerIdPOptions) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
setOptions(GetWorkerIdPOptions.Builder) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
optional .alluxio.grpc.block.GetWorkerIdPOptions options = 2;
setOptions(JobHeartbeatPOptions) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
setOptions(JobHeartbeatPOptions.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobHeartbeatPOptions options = 3;
setOptions(JobMasterHeartbeatPOptions) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
setOptions(JobMasterHeartbeatPOptions.Builder) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
optional .alluxio.grpc.job.JobMasterHeartbeatPOptions options = 2;
setOptions(ListAllPOptions) - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
setOptions(ListAllPOptions.Builder) - Method in class alluxio.grpc.ListAllPRequest.Builder
optional .alluxio.grpc.job.ListAllPOptions options = 1;
setOptions(ListPolicyPOptions) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
setOptions(ListPolicyPOptions.Builder) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
optional .alluxio.grpc.policy.ListPolicyPOptions options = 1;
setOptions(ListProxyStatusPOptions) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
setOptions(ListProxyStatusPOptions.Builder) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
optional .alluxio.grpc.meta.ListProxyStatusPOptions options = 1;
setOptions(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
setOptions(ListStatusPOptions.Builder) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 1;
setOptions(ListStatusPartialPOptions) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
setOptions(ListStatusPartialPOptions.Builder) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
optional .alluxio.grpc.file.ListStatusPartialPOptions options = 2;
setOptions(ListStatusPOptions) - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
setOptions(ListStatusPOptions.Builder) - Method in class alluxio.grpc.ListStatusPRequest.Builder
optional .alluxio.grpc.file.ListStatusPOptions options = 2;
setOptions(UfsReadOptions) - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
setOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.LoadFileRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
setOptions(UfsReadOptions) - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
setOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.LoadRequest.Builder
required .alluxio.grpc.block.UfsReadOptions options = 2;
setOptions(MasterHeartbeatPOptions) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
setOptions(MasterHeartbeatPOptions.Builder) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.MasterHeartbeatPOptions options = 2;
setOptions(MetricsHeartbeatPOptions) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
setOptions(MetricsHeartbeatPOptions.Builder) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
optional .alluxio.grpc.metric.MetricsHeartbeatPOptions options = 1;
setOptions(MountPOptions) - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
setOptions(MountPOptions.Builder) - Method in class alluxio.grpc.MountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
setOptions(NotifyWorkerIdPOptions) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
setOptions(NotifyWorkerIdPOptions.Builder) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional .alluxio.grpc.block.NotifyWorkerIdPOptions options = 3;
setOptions(AddPolicyPOptions) - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
setOptions(AddPolicyPOptions.Builder) - Method in class alluxio.grpc.PolicyInfo.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
setOptions(ProxyHeartbeatPOptions) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
setOptions(ProxyHeartbeatPOptions.Builder) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
optional .alluxio.grpc.meta.ProxyHeartbeatPOptions options = 1;
setOptions(RegisterJobMasterPOptions) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
setOptions(RegisterJobMasterPOptions.Builder) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
optional .alluxio.grpc.job.RegisterJobMasterPOptions options = 2;
setOptions(RegisterJobWorkerPOptions) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
setOptions(RegisterJobWorkerPOptions.Builder) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.job.RegisterJobWorkerPOptions options = 2;
setOptions(RegisterMasterPOptions) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
setOptions(RegisterMasterPOptions.Builder) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
optional .alluxio.grpc.meta.RegisterMasterPOptions options = 2;
setOptions(RegisterWorkerPOptions) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
setOptions(RegisterWorkerPOptions.Builder) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
optional .alluxio.grpc.block.RegisterWorkerPOptions options = 6;
setOptions(RemovePathConfigurationPOptions) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
setOptions(RemovePathConfigurationPOptions.Builder) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.RemovePathConfigurationPOptions options = 3;
setOptions(RemovePolicyPOptions) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
setOptions(RemovePolicyPOptions.Builder) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional .alluxio.grpc.policy.RemovePolicyPOptions options = 2;
setOptions(RemoveQuorumServerPOptions) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
setOptions(RemoveQuorumServerPOptions.Builder) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.journal.RemoveQuorumServerPOptions options = 1;
setOptions(RenamePOptions) - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
setOptions(RenamePOptions.Builder) - Method in class alluxio.grpc.RenamePRequest.Builder
optional .alluxio.grpc.file.RenamePOptions options = 3;
setOptions(ResetPrioritiesPOptions) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
setOptions(ResetPrioritiesPOptions.Builder) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
optional .alluxio.grpc.journal.ResetPrioritiesPOptions options = 1;
setOptions(RunPOptions) - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
setOptions(RunPOptions.Builder) - Method in class alluxio.grpc.RunPRequest.Builder
optional .alluxio.grpc.job.RunPOptions options = 2;
setOptions(ScheduleAsyncPersistencePOptions) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
setOptions(ScheduleAsyncPersistencePOptions.Builder) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
optional .alluxio.grpc.file.ScheduleAsyncPersistencePOptions options = 2;
setOptions(SetAclPOptions) - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
setOptions(SetAclPOptions.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
the method options
setOptions(SetAttributePOptions) - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
setOptions(SetAttributePOptions.Builder) - Method in class alluxio.grpc.SetAttributePRequest.Builder
optional .alluxio.grpc.file.SetAttributePOptions options = 2;
setOptions(SetPathConfigurationPOptions) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
setOptions(SetPathConfigurationPOptions.Builder) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional .alluxio.grpc.meta.SetPathConfigurationPOptions options = 3;
setOptions(SubmitOptions) - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
setOptions(SubmitOptions.Builder) - Method in class alluxio.grpc.SubmitRequest.Builder
optional .alluxio.grpc.job.SubmitOptions options = 2;
setOptions(TransferLeadershipPOptions) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
setOptions(TransferLeadershipPOptions.Builder) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.journal.TransferLeadershipPOptions options = 1;
setOptions(UnmountPOptions) - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
setOptions(UnmountPOptions.Builder) - Method in class alluxio.grpc.UnmountPRequest.Builder
optional .alluxio.grpc.file.UnmountPOptions options = 2;
setOptions(MountPOptions) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
setOptions(MountPOptions.Builder) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
optional .alluxio.grpc.file.MountPOptions options = 3;
setOptions(UpdateUfsModePOptions) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
setOptions(UpdateUfsModePOptions.Builder) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
optional .alluxio.grpc.file.UpdateUfsModePOptions options = 2;
setOptions(AddPolicyPOptions) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
setOptions(AddPolicyPOptions.Builder) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
optional .alluxio.grpc.policy.AddPolicyPOptions options = 4;
setOptions(UnixMountInfo.Options) - Method in class alluxio.util.UnixMountInfo.Builder
 
setOrder(SortingColumn.SortingOrder) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
required .alluxio.grpc.table.layout.SortingColumn.SortingOrder order = 2;
setOrderedTierAliases(List<String>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets ordered tier aliases.
setOssClientBuilder(OSSClientBuilder) - Method in class alluxio.underfs.oss.StsOssClientProvider
 
setOtherActions(Acl.AclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
setOtherActions(Acl.AclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional .alluxio.proto.shared.AclActions otherActions = 6;
setOtherBits(Bits) - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits otherBits = 3;
setOtherBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets other bits.
setOutput(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task output.
setOutputFormat(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string output_format = 3;
setOutputFormatBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string output_format = 3;
setOutputStream(OutputStream) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
setOutputStream(OutputStream) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
setOverheadRatio(double) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setOverwrite(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool overwrite = 4;
setOverwrite(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool overwrite = 13;
setOverwrite(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool overwrite = 4;
setOverwrite(boolean) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
optional bool overwrite = 1;
setOverwrite(boolean) - Method in class alluxio.grpc.WriteOptions.Builder
optional bool overwrite = 1;
setOverwrite(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional bool overwrite = 10;
setOverwrite(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional bool overwrite = 10;
setOverwriteAccessTime(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_access_time = 19;
setOverwriteModificationTime(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool overwrite_modification_time = 8;
setOwner(String) - Method in class alluxio.client.file.options.OutStreamOptions
 
setOwner(String, String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
setOwner(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string owner = 16;
setOwner(String) - Method in class alluxio.grpc.PAcl.Builder
optional string owner = 1;
setOwner(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string owner = 3;
setOwner(String) - Method in class alluxio.grpc.table.TableInfo.Builder
optional string owner = 4;
setOwner(String) - Method in class alluxio.grpc.UfsStatus.Builder
optional string owner = 4;
setOwner(Path, String, String) - Method in class alluxio.hadoop.AbstractFileSystem
Changes owner or group of a path (i.e.
setOwner(String) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setOwner(String) - Method in class alluxio.master.file.meta.MutableInode
 
setOwner(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
setOwner(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
setOwner(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
setOwner(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
setOwner(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string owner = 9;
setOwner(String, String, String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.adl.AdlUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.cos.COSUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.gcs.v2.GCSV2UnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.obs.OBSUnderFileSystem
 
setOwner(String) - Method in class alluxio.underfs.options.CreateOptions
 
setOwner(String) - Method in class alluxio.underfs.options.MkdirsOptions
 
setOwner(String, String, String) - Method in class alluxio.underfs.oss.OSSUnderFileSystem
 
setOwner(String, String, String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystem
 
setOwner(String, String, String) - Method in interface alluxio.underfs.UnderFileSystem
Sets the user and group of the given path.
setOwner(String, String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setOwner(String) - Method in class alluxio.wire.FileInfo
 
setOwnerBits(Bits) - Method in class alluxio.grpc.PMode.Builder
required .alluxio.grpc.Bits ownerBits = 1;
setOwnerBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets owner bits.
setOwnerBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string owner = 16;
setOwnerBytes(ByteString) - Method in class alluxio.grpc.PAcl.Builder
optional string owner = 1;
setOwnerBytes(ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional string owner = 3;
setOwnerBytes(ByteString) - Method in class alluxio.grpc.table.TableInfo.Builder
optional string owner = 4;
setOwnerBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
optional string owner = 4;
setOwnerBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string owner = 2;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string owner = 8;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string owner = 14;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string owner = 6;
setOwnerBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string owner = 9;
setOwnerName(String) - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
setOwnerNameBytes(ByteString) - Method in class alluxio.grpc.table.Database.Builder
optional string owner_name = 5;
setOwnerType(PrincipalType) - Method in class alluxio.grpc.table.Database.Builder
optional .alluxio.grpc.table.PrincipalType owner_type = 6;
setOwningGroup(String) - Method in class alluxio.grpc.PAcl.Builder
optional string owningGroup = 2;
setOwningGroup(String) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningGroup = 2;
setOwningGroup(String) - Method in class alluxio.security.authorization.AccessControlList
Sets owning group.
setOwningGroupBytes(ByteString) - Method in class alluxio.grpc.PAcl.Builder
optional string owningGroup = 2;
setOwningGroupBytes(ByteString) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningGroup = 2;
setOwningUser(String) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningUser = 1;
setOwningUser(String) - Method in class alluxio.security.authorization.AccessControlList
Sets owning user.
setOwningUserBytes(ByteString) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
optional string owningUser = 1;
setPacketReaderActive(boolean) - Method in class alluxio.worker.netty.ReadRequestContext
 
setPacketWriterActive(boolean) - Method in class alluxio.worker.netty.WriteRequestContext
 
setPageSize(long) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setPageSize(long) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setPageSize(long) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
optional int64 pageSize = 1;
setPageStoreOptions(List<PageStoreOptions>) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setParameters(ClientIOParameters) - Method in class alluxio.stress.client.ClientIOSummary
 
setParameters(ClientIOParameters) - Method in class alluxio.stress.client.ClientIOTaskResult
 
setParameters(UfsIOParameters) - Method in class alluxio.stress.worker.IOTaskResult
 
setParameters(UfsIOParameters) - Method in class alluxio.stress.worker.IOTaskSummary
 
setParameters(WorkerBenchParameters) - Method in class alluxio.stress.worker.WorkerBenchSummary
 
setParameters(WorkerBenchParameters) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setParentId(long) - Method in class alluxio.grpc.JobInfo.Builder
optional int64 parentId = 10;
setParentId(long) - Method in class alluxio.master.file.meta.MutableInode
 
setParentId(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 parent_id = 2;
setParentId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 parent_id = 2;
setParentId(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 parent_id = 2;
setParentId(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 parent_id = 7;
setPartialListing(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool partialListing = 3;
setPartialListing(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool partialListing = 3;
setPartialListing(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool partialListing = 3;
setPartialListing(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool partialListing = 7;
setPartialListing(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool partialListing = 6;
setPartialListing(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool partialListing = 7;
setPartitionCols(int, FieldSchema) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
setPartitionCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
setPartitionName(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
partition name in the form of "key=value"
setPartitionNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
partition name in the form of "key=value"
setPartitions(int, Partition) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
setPartitions(int, Partition.Builder) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
setPartitionSpec(PartitionSpec) - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
setPartitionSpec(PartitionSpec.Builder) - Method in class alluxio.grpc.table.Partition.Builder
optional .alluxio.grpc.table.PartitionSpec partition_spec = 1;
setPartNames(int, String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
setPartNumber(int) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setParts(List<CompleteMultipartUploadRequest.Part>) - Method in class alluxio.proxy.s3.CompleteMultipartUploadRequest
 
setParts(List<ListPartsResult.Part>) - Method in class alluxio.proxy.s3.ListPartsResult
 
setPath(String) - Method in class alluxio.fuse.CreateFileEntry
Sets the path of the file.
setPath(String) - Method in class alluxio.fuse.OpenFileEntry
Sets the path of the file.
setPath(String) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
the root of the subtree to check
setPath(String) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
the path of the file
setPath(String) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
the path of the directory
setPath(String) - Method in class alluxio.grpc.CreateFilePRequest.Builder
the path of the file
setPath(String) - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
setPath(String) - Method in class alluxio.grpc.ExistsPRequest.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string path = 3;
setPath(String) - Method in class alluxio.grpc.FreePRequest.Builder
the path of the file or directory
setPath(String) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
the path of the file
setPath(String) - Method in class alluxio.grpc.GetStatusPRequest.Builder
the path of the file or directory
setPath(String) - Method in class alluxio.grpc.JobDescription.Builder
optional string path = 2;
setPath(String) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
the path of the file or directory
setPath(String) - Method in class alluxio.grpc.ListStatusPRequest.Builder
the path of the file or directory
setPath(String) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
required string path = 1;
setPath(String) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.grpc.RenamePRequest.Builder
the source path of the file or directory
setPath(String) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
the path of the file
setPath(String) - Method in class alluxio.grpc.SetAclPRequest.Builder
the path of the file or directory
setPath(String) - Method in class alluxio.grpc.SetAttributePRequest.Builder
the path of the file
setPath(String) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.job.JobDescription.Builder
set path.
setPath(String) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional string path = 5;
setPath(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string path = 17;
setPath(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string path = 25;
setPath(String) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string path = 6;
setPath(String) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string path = 12;
setPath(String) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
optional string path = 1;
setPath(String) - Method in class alluxio.wire.FileInfo
 
setPath(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets path.
setPathBytes(ByteString) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
the root of the subtree to check
setPathBytes(ByteString) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
the path of the file
setPathBytes(ByteString) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
the path of the directory
setPathBytes(ByteString) - Method in class alluxio.grpc.CreateFilePRequest.Builder
the path of the file
setPathBytes(ByteString) - Method in class alluxio.grpc.DeletePRequest.Builder
the path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.ExistsPRequest.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string path = 3;
setPathBytes(ByteString) - Method in class alluxio.grpc.FreePRequest.Builder
the path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
the path of the file
setPathBytes(ByteString) - Method in class alluxio.grpc.GetStatusPRequest.Builder
the path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.JobDescription.Builder
optional string path = 2;
setPathBytes(ByteString) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
the path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.ListStatusPRequest.Builder
the path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
required string path = 1;
setPathBytes(ByteString) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.grpc.RenamePRequest.Builder
the source path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
the path of the file
setPathBytes(ByteString) - Method in class alluxio.grpc.SetAclPRequest.Builder
the path of the file or directory
setPathBytes(ByteString) - Method in class alluxio.grpc.SetAttributePRequest.Builder
the path of the file
setPathBytes(ByteString) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
optional string path = 5;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string path = 17;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string path = 25;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
optional string path = 6;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string path = 12;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
optional string path = 1;
setPathBytes(ByteString) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
optional string path = 1;
setPathConfHash(String) - Method in class alluxio.wire.Configuration.Builder
Sets hash of path configurations.
setPathConfigHash(String) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string pathConfigHash = 2;
setPathConfigHash(String) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string pathConfigHash = 4;
setPathConfigHash(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets path config hash.
setPathConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
optional string pathConfigHash = 2;
setPathConfigHashBytes(ByteString) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional string pathConfigHash = 4;
setPathConfigLastUpdateTime(long) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
optional int64 pathConfigLastUpdateTime = 6;
setPathConfigLastUpdateTime(String) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets the path config last update time.
setPathConfiguration(AlluxioURI, PropertyKey, String) - Method in interface alluxio.client.meta.MetaMasterConfigClient
Sets a property for a path.
setPathConfiguration(AlluxioURI, Map<PropertyKey, String>) - Method in interface alluxio.client.meta.MetaMasterConfigClient
Sets properties for a path.
setPathConfiguration(AlluxioURI, Map<PropertyKey, String>) - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
setPathConfiguration(SetPathConfigurationPRequest, StreamObserver<SetPathConfigurationPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
Sets a property for a path.
setPathConfiguration(SetPathConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
Sets a property for a path.
setPathConfiguration(SetPathConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
Sets a property for a path.
setPathConfiguration(SetPathConfigurationPRequest, StreamObserver<SetPathConfigurationPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
Sets a property for a path.
setPathConfiguration(String, Map<PropertyKey, String>) - Method in class alluxio.master.meta.DefaultMetaMaster
 
setPathConfiguration(String, Map<PropertyKey, String>) - Method in interface alluxio.master.meta.MetaMaster
Sets properties for a path.
setPathConfiguration(SetPathConfigurationPRequest, StreamObserver<SetPathConfigurationPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
 
SetPathConfigurationPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SetPathConfigurationPOptions
SetPathConfigurationPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SetPathConfigurationPOptions
SetPathConfigurationPOptionsOrBuilder - Interface in alluxio.grpc
 
SetPathConfigurationPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SetPathConfigurationPRequest
SetPathConfigurationPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SetPathConfigurationPRequest
SetPathConfigurationPRequestOrBuilder - Interface in alluxio.grpc
 
SetPathConfigurationPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SetPathConfigurationPResponse
SetPathConfigurationPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SetPathConfigurationPResponse
SetPathConfigurationPResponseOrBuilder - Interface in alluxio.grpc
 
setPathConfLastUpdateTime(long) - Method in class alluxio.wire.Configuration.Builder
Sets path config last update time.
setPathInfos(UIFileInfo[]) - Method in class alluxio.wire.MasterWebUIBrowse
Sets path infos.
setPathProperties(Meta.PathPropertiesEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
setPathProperties(Meta.PathPropertiesEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PathPropertiesEntry path_properties = 40;
setPattern(String) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
optional string pattern = 2;
setPatternBytes(ByteString) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
optional string pattern = 2;
setPendingCount(int) - Method in class alluxio.concurrent.jsr.CountedCompleter
Sets the pending count to the given value.
setPermission(Path, FsPermission) - Method in class alluxio.hadoop.AbstractFileSystem
Changes permission of a path.
setPermission(int) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 permission = 8;
setPermissionError(String) - Method in class alluxio.wire.MasterWebUIData
Sets permission error.
setPersist(boolean) - Method in class alluxio.grpc.RenamePOptions.Builder
optional bool persist = 2;
setPersistDirectory(File.PersistDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
setPersistDirectory(File.PersistDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PersistDirectoryEntry persist_directory = 15;
setPersisted(boolean) - Method in class alluxio.grpc.FileInfo.Builder
optional bool persisted = 12;
setPersisted(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool persisted = 2;
setPersisted(boolean) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool persisted = 5;
setPersisted(boolean) - Method in class alluxio.wire.FileInfo
 
setPersistedFileFingerprints(int, String) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
setPersistedFiles(int, long) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the list of persisted files
setPersistenceState(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string persistenceState = 19;
setPersistenceState(PersistenceState) - Method in class alluxio.master.file.meta.MutableInode
 
setPersistenceState(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
setPersistenceState(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
setPersistenceState(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string persistence_state = 4;
setPersistenceState(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persistence_state = 8;
setPersistenceState(String) - Method in class alluxio.wire.FileInfo
 
setPersistenceStateBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string persistenceState = 19;
setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional string persistence_state = 4;
setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string persistence_state = 4;
setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string persistence_state = 4;
setPersistenceStateBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persistence_state = 8;
setPersistenceWaitTime(long) - Method in class alluxio.client.file.options.OutStreamOptions
 
setPersistenceWaitTime(long) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int64 persistenceWaitTime = 10;
setPersistenceWaitTime(long) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
optional int64 persistenceWaitTime = 2;
setPersistFiles(int, PersistFile) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
setPersistFiles(int, PersistFile.Builder) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
setPersistJobId(long) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setPersistJobId(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 persist_job_id = 22;
setPersistJobId(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 persistJobId = 11;
setPersistJobId(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int64 persist_job_id = 10;
setPersistJobId(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
Used for recovering in-progress file persist jobs on master start.
setPersistJobTempUfsPath(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persist_job_temp_ufs_path = 24;
setPersistJobTempUfsPathBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string persist_job_temp_ufs_path = 24;
setPersistOptions(PersistCommandOptions) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
setPersistOptions(PersistCommandOptions.Builder) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
optional .alluxio.grpc.file.PersistCommandOptions persistOptions = 1;
setPersistOptions(PersistCommandOptions) - Method in class alluxio.wire.FileSystemCommandOptions
Set the persist options.
setPinned(FileSystem, AlluxioURI, boolean, List<String>) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
Sets pin state for the input path.
setPinned(boolean) - Method in class alluxio.grpc.FileInfo.Builder
optional bool pinned = 10;
setPinned(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool pinned = 1;
setPinned(RpcContext, LockedInodePath, boolean, List<String>, long) - Method in class alluxio.master.file.meta.InodeTree
Sets the pinned state of an inode.
setPinned(boolean) - Method in class alluxio.master.file.meta.MutableInode
 
setPinned(boolean) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional bool pinned = 5;
setPinned(boolean) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional bool pinned = 5;
setPinned(boolean) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional bool pinned = 3;
setPinned(boolean) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional bool pinned = 5;
setPinned(boolean) - Method in class alluxio.wire.FileInfo
 
setPinnedFileIds(int, long) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
TODO(adit): set replacement?
setPinnedMedia(int, String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
setPinOnCreate(boolean) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional bool pin_on_create = 9;
setPoints(List<IOTaskResult.Point>) - Method in class alluxio.stress.worker.IOTaskResult
 
setPoints(List<IOTaskResult.Point>) - Method in class alluxio.stress.worker.IOTaskSummary
 
setPolicy(PolicyInfo) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
setPolicy(PolicyInfo.Builder) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
optional .alluxio.grpc.policy.PolicyInfo policy = 1;
setPolicy(int, PolicyInfo) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
setPolicy(int, PolicyInfo.Builder) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
setPolicyDefinition(Policy.PolicyDefinitionEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
setPolicyDefinition(Policy.PolicyDefinitionEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyDefinitionEntry policy_definition = 56;
setPolicyName(String) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional string policyName = 1;
setPolicyName(String) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string policyName = 1;
setPolicyName(String) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional string policyName = 1;
setPolicyName(String) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional string policyName = 1;
setPolicyName(String) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
optional string policyName = 1;
setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
optional string policyName = 1;
setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
optional string policyName = 1;
setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
optional string policyName = 1;
setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
optional string policyName = 1;
setPolicyNameBytes(ByteString) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
optional string policyName = 1;
setPolicyRemove(Policy.PolicyRemoveEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
setPolicyRemove(Policy.PolicyRemoveEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.PolicyRemoveEntry policy_remove = 57;
setPort(int) - Method in class alluxio.master.CoreMasterContext.Builder
 
setPos(long) - Method in class alluxio.worker.grpc.WriteRequestContext
 
setPositionShort(boolean) - Method in class alluxio.grpc.ReadRequest.Builder
Is position read to a small buffer
setPositionShort(boolean) - Method in class alluxio.grpc.UfsReadOptions.Builder
is position short or not, used for HDFS performance optimization.
setPositionShort(boolean) - Method in class alluxio.underfs.options.OpenOptions
 
setPosReceived(long) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setPosToQueue(long) - Method in class alluxio.worker.grpc.BlockReadRequestContext
 
setPosToQueue(long) - Method in class alluxio.worker.netty.ReadRequestContext
 
setPosToQueue(long) - Method in class alluxio.worker.netty.WriteRequestContext
 
setPosToWrite(long) - Method in class alluxio.worker.netty.ReadRequestContext
 
setPosToWrite(long) - Method in class alluxio.worker.netty.WriteRequestContext
 
setPrefix(String) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only match files with a given prefix.
setPrefix(String) - Method in class alluxio.master.metastore.ReadOption.Builder
Set the prefix of the path to filter children by.
setPrefix(String) - Method in class alluxio.s3.ListBucketOptions
 
setPrefixBytes(ByteString) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Only match files with a given prefix.
setPreviousVersion(long) - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 previous_version = 9;
setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalReaderOptions
 
setPrimary(boolean) - Method in class alluxio.master.journal.options.JournalWriterOptions
 
setPrimaryMasterInfo(MasterInfo) - Method in class alluxio.wire.MasterWebUIMasters
Sets primary master info.
setPrimarySelector(PrimarySelector) - Method in class alluxio.master.CoreMasterContext.Builder
 
setPriority(int) - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional int32 priority = 4;
setPriority(int) - Method in class alluxio.scheduler.job.Task
Set priority.
setProgressPercentage(float) - Method in class alluxio.grpc.CmdSummary.Builder
optional float progressPercentage = 9;
setProgressReport(String) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional string progressReport = 1;
setProgressReportBytes(ByteString) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
optional string progressReport = 1;
setPromote(boolean) - Method in class alluxio.grpc.ReadRequest.Builder
Whether the block should be promoted before reading
setPromote(boolean) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
optional bool promote = 2;
setPromote(boolean) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
Whether the block should be promoted before reading
setProperties(int, ConfigProperty) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
setProperties(int, ConfigProperty.Builder) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
setProperties(int, InconsistentProperty) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
setProperties(int, InconsistentProperty.Builder) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
setProperties(MountPOptions) - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
setProperties(MountPOptions.Builder) - Method in class alluxio.grpc.UfsInfo.Builder
optional .alluxio.grpc.file.MountPOptions properties = 2;
setProperties(int, File.StringPairEntry) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
setProperties(int, File.StringPairEntry.Builder) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
setProperties(Map<String, String>) - Method in class alluxio.wire.MountPointInfo
 
setProperty(PropertyKey, String) - Method in class alluxio.master.LocalAlluxioJobCluster
Overrides properties for the Job Master and Worker before starting.
setProxyAddress(NetAddress) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
setProxyAddress(NetAddress.Builder) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.NetAddress proxyAddress = 1;
setProxyDownloadFileApiUrl(Map<String, String>) - Method in class alluxio.wire.MasterWebUIInit
Sets proxy download file api url.
setProxyStatuses(int, ProxyStatus) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
setProxyStatuses(int, ProxyStatus.Builder) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
setQuiet(boolean) - Method in class alluxio.s3.DeleteObjectsRequest
sets the quiet parameter.
setQuietTimeMs(long) - Method in class alluxio.master.journal.JournalSystem.Builder
 
setQuota(String, long) - Method in class alluxio.underfs.UfsIOManager
Set throughput quota for tag.
setQuotaEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setRaftAddress(int, String) - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
setRaftJournal(boolean) - Method in class alluxio.grpc.MasterInfo.Builder
optional bool raftJournal = 12;
setRaftJournalAddress(List<String>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set raft journal address.
setRange(RangeSet) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
setRange(RangeSet.Builder) - Method in class alluxio.grpc.table.Domain.Builder
.alluxio.grpc.table.RangeSet range = 1;
setRanges(int, Range) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
setRanges(int, Range.Builder) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
setRawResult(T) - Method in class alluxio.concurrent.jsr.CountedCompleter
A method that result-bearing CountedCompleters may optionally use to help maintain result data.
setRawResult(V) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Forces the given value to be returned as a result.
setRawValue(boolean) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
optional bool rawValue = 1;
setReadFrom(String) - Method in class alluxio.master.metastore.ReadOption.Builder
Set the path where to start traversing the list of children from.
setReadOnly(boolean) - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool readOnly = 5;
setReadOnly(boolean) - Method in class alluxio.grpc.MountPOptions.Builder
optional bool readOnly = 1;
setReadOnly(boolean) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool readOnly = 3;
setReadOnly(boolean) - Method in class alluxio.wire.MountPointInfo
 
setReadSpeedStat(IOTaskSummary.SpeedStat) - Method in class alluxio.stress.worker.IOTaskSummary
 
setReadType(ReadPType) - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional .alluxio.grpc.file.ReadPType readType = 1;
setRecentActivities(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
setRecentActivities(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
setRecentFailedJobs(List<JobServiceOutput.SerializableJobInfo>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Set recent failed jobs.
setRecentFailures(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
setRecentFailures(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
setRecentModifiedJobs(List<JobServiceOutput.SerializableJobInfo>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Set recent modified jobs.
setRecordStartMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult
 
setRecordStartMs(long) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
setRecordStartMs(long) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setRecoverFailedOpen(boolean) - Method in class alluxio.underfs.options.OpenOptions
 
setRecursive(boolean) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional bool recursive = 1;
setRecursive(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool recursive = 2;
setRecursive(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool recursive = 1;
setRecursive(boolean) - Method in class alluxio.grpc.FreePOptions.Builder
optional bool recursive = 1;
setRecursive(boolean) - Method in class alluxio.grpc.ListStatusPOptions.Builder
optional bool recursive = 4;
setRecursive(boolean) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
whether to load metadata recursively
setRecursive(boolean) - Method in class alluxio.grpc.SetAclPOptions.Builder
optional bool recursive = 2;
setRecursive(boolean) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional bool recursive = 6;
setRecursive(boolean) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
Deprecated, we now write one journal entry per inode removed
setRecursive(boolean) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
optional bool recursive = 5;
setRecursive(boolean) - Method in class alluxio.underfs.options.DeleteOptions
Sets recursive delete.
setRecursive(boolean) - Method in class alluxio.underfs.options.ListOptions
Sets recursive list.
setRefreshInterval(int) - Method in class alluxio.wire.MasterWebUIInit
Sets refresh interval.
setRefreshInterval(int) - Method in class alluxio.wire.WorkerWebUIInit
Sets refresh interval.
setRegisterCommand(RegisterCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
setRegisterCommand(RegisterCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RegisterCommand registerCommand = 3;
setRemovedBlockIds(int, long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the list of removed block ids
setRemovePathProperties(Meta.RemovePathPropertiesEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
setRemovePathProperties(Meta.RemovePathPropertiesEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemovePathPropertiesEntry remove_path_properties = 41;
setRemoveSyncPoint(File.RemoveSyncPointEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
setRemoveSyncPoint(File.RemoveSyncPointEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RemoveSyncPointEntry remove_sync_point = 33;
setRename(File.RenameEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
setRename(File.RenameEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.RenameEntry rename = 19;
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ActionInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupPStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Block.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockIdList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockLocation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.BuildVersion.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CacheRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CacheResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CheckResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Chunk.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ClientMetrics.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CmdProgress.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CmdSummary.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Command.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ConfigProperties.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ConfigProperty.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CopyRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CopyResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DeletePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DeletePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DeletePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ErrorInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.File.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileFailure.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.FsOpPId.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobCommand.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobDescription.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobProgress.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobUnused.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LoadResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MasterVersion.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Metric.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MetricValue.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPointInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MountPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.MoveResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NetAddress.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PAcl.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PAclEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PersistFile.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PMode.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PolicyInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.PolicyStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ProxyStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReadRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReadResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterCommand.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RenamePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RenamePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RenamePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RetryInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.Route.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RouteFailure.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SaslMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SnapshotData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StatusSummary.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.StorageList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.SubmitResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Constraint.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Database.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Date.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Decimal.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Domain.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Layout.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Partition.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Range.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.RangeSet.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Schema.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TableInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Transformation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.table.Value.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TierList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TransportMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UfsStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.grpc.WriteResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
setReplicaBlockCount(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets replica block count.
setReplication(Path, short) - Method in class alluxio.hadoop.AbstractFileSystem
 
setReplication(RpcContext, LockedInodePath, Integer, Integer, long) - Method in class alluxio.master.file.meta.InodeTree
Sets the min and/or max replication level of an inode.
setReplicationDurable(int) - Method in class alluxio.client.file.options.OutStreamOptions
 
setReplicationDurable(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationDurable = 6;
setReplicationDurable(int) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setReplicationDurable(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_durable = 24;
setReplicationDurable(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_durable = 20;
setReplicationMax(int) - Method in class alluxio.client.file.options.OutStreamOptions
 
setReplicationMax(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMax = 4;
setReplicationMax(int) - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMax = 29;
setReplicationMax(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMax = 7;
setReplicationMax(int) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setReplicationMax(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_max = 20;
setReplicationMax(int) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_max = 13;
setReplicationMax(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_max = 8;
setReplicationMax(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_max = 21;
setReplicationMax(int) - Method in class alluxio.wire.FileInfo
 
setReplicationMin(int) - Method in class alluxio.client.file.options.OutStreamOptions
 
setReplicationMin(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 replicationMin = 5;
setReplicationMin(int) - Method in class alluxio.grpc.FileInfo.Builder
optional int32 replicationMin = 30;
setReplicationMin(int) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional int32 replicationMin = 8;
setReplicationMin(int) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setReplicationMin(int) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int32 replication_min = 21;
setReplicationMin(int) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int32 replication_min = 14;
setReplicationMin(int) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional int32 replication_min = 9;
setReplicationMin(int) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int32 replication_min = 22;
setReplicationMin(int) - Method in class alluxio.wire.FileInfo
 
setReport(ConfigCheckReport) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
setReport(ConfigCheckReport.Builder) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
optional .alluxio.grpc.meta.ConfigCheckReport report = 1;
setRequestBody(ByteString) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
optional bytes request_body = 1;
setRequestHeader(MessagingRequestHeader) - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
setRequestHeader(MessagingRequestHeader.Builder) - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingRequestHeader requestHeader = 1;
setRequestId(long) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
optional int64 requestId = 1;
setRequestId(long) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
optional int64 requestId = 1;
setRequestId(String) - Method in class alluxio.s3.S3Error
 
setResource(String) - Method in class alluxio.s3.S3Error
 
setResource(String) - Method in exception alluxio.s3.S3Exception
 
setResponse(HttpResponse) - Method in class alluxio.worker.s3.S3NettyHandler
set FullHttpResponse for this request.
setResponseHeader(MessagingResponseHeader) - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
setResponseHeader(MessagingResponseHeader.Builder) - Method in class alluxio.grpc.TransportMessage.Builder
optional .alluxio.grpc.messaging.MessagingResponseHeader responseHeader = 2;
setResult(Map<ValidationUtils.State, List<ValidationTaskResult>>) - Method in class alluxio.cli.ValidationResults
Set validation results.
setResult(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
optional bytes result = 9;
setResult(String) - Method in class alluxio.job.plan.meta.PlanInfo
 
setResult(Serializable) - Method in class alluxio.job.wire.TaskInfo
 
setRetryable(boolean) - Method in class alluxio.grpc.BlockStatus.Builder
optional bool retryable = 4;
setRetryable(boolean) - Method in class alluxio.grpc.FileFailure.Builder
optional bool retryable = 4;
setRetryable(boolean) - Method in class alluxio.grpc.LoadFileFailure.Builder
optional bool retryable = 4;
setRetryable(boolean) - Method in class alluxio.grpc.RouteFailure.Builder
optional bool retryable = 4;
setRevision(String) - Method in class alluxio.grpc.BuildVersion.Builder
the git revision at the time of building
setRevision(String) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string revision = 5;
setRevision(String) - Method in class alluxio.master.meta.MasterInfo
 
setRevision(String) - Method in class alluxio.master.meta.ProxyInfo
 
setRevision(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setRevision(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setRevision(String) - Method in class alluxio.wire.MasterInfo
 
setRevision(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets revision.
setRevision(String) - Method in class alluxio.wire.WorkerInfo
 
setRevision(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets revision.
setRevisionBytes(ByteString) - Method in class alluxio.grpc.BuildVersion.Builder
the git revision at the time of building
setRevisionBytes(ByteString) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string revision = 5;
setRevisionNumber(long) - Method in class alluxio.membership.DefaultServiceEntity
Set revision number.
setRootDir(Path) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setRoute(Route) - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
setRoute(Route.Builder) - Method in class alluxio.grpc.RouteFailure.Builder
required .alluxio.grpc.block.Route route = 1;
setRoutes(int, Route) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
setRoutes(int, Route.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
setRoutes(int, Route) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
setRoutes(int, Route.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
setRpcAddress(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setRpcAddress(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setRpcInvocationMetrics(Map<String, Counter>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets rpc invocation metrics.
setRpcPort(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set rpc port.
setRpcPort(int) - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 rpcPort = 3;
setRpcPort(int) - Method in class alluxio.grpc.NetAddress.Builder
optional int32 rpcPort = 2;
setRpcPort(int) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 rpcPort = 2;
setRpcPort(int) - Method in class alluxio.wire.Address
 
setRpcPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setRpcQueueLength(long) - Method in class alluxio.wire.WorkerWebUIOperations
Sets the RPC queue length.
setRunAsync(boolean) - Method in class alluxio.grpc.BackupPOptions.Builder
optional bool runAsync = 2;
setRunTaskCommand(RunTaskCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
setRunTaskCommand(RunTaskCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.RunTaskCommand runTaskCommand = 1;
setS3SyntaxOptions(S3SyntaxOptions) - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
setS3SyntaxOptions(S3SyntaxOptions.Builder) - Method in class alluxio.grpc.RenamePOptions.Builder
optional .alluxio.grpc.file.S3SyntaxOptions s3SyntaxOptions = 3;
setS3Task(S3BaseTask) - Method in class alluxio.proxy.s3.S3Handler
set S3Task for this S3Handler.
setS3Task(S3NettyBaseTask) - Method in class alluxio.worker.s3.S3NettyHandler
set S3Task for this S3Handler.
setSafeMode(boolean) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set if in safe mode.
setSafeMode(boolean) - Method in class alluxio.grpc.MasterInfo.Builder
optional bool safeMode = 4;
setSafeModeManager(SafeModeManager) - Method in class alluxio.master.CoreMasterContext.Builder
 
setScale(int) - Method in class alluxio.grpc.table.Decimal.Builder
force using scale first in Decimal.compareTo
setScanCompleted(long) - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanCompleted = 4;
setScanPendingAction(long) - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanPendingAction = 3;
setScanStartedMs(long) - Method in class alluxio.grpc.PolicyStatus.Builder
scan status
setScanTotal(long) - Method in class alluxio.grpc.PolicyStatus.Builder
optional int64 scanTotal = 2;
setSchema(Schema) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
setSchema(Schema.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.Schema schema = 5;
setScope(Scope) - Method in class alluxio.conf.PropertyKey.Builder
 
setSecond(T2) - Method in class alluxio.collections.Pair
Set the second value.
setSecond(LockedInodePath) - Method in class alluxio.master.file.meta.InodePathPair
 
setSecureRpcPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setSecurityAuthorizationPermissionEnabled(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets security authorization permission enabled.
setSecurityAuthorizationPermissionEnabled(boolean) - Method in class alluxio.wire.WorkerWebUIInit
Sets security authorization permission enabled.
setSelectionPolicy(DynamicResourcePool.SelectionPolicy) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setSequenceNumber(long) - Method in class alluxio.master.file.state.DirectoryId
 
setSequenceNumber(long) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
optional int64 sequence_number = 2;
setSequenceNumber(long) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
shared fields.
setSerde(String) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string serde = 1;
setSerdeBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
optional string serde = 1;
setServerAddress(NetAddress) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
setServerAddress(NetAddress) - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.NetAddress serverAddress = 1;
setServerAddress(NetAddress) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
setServerAddress(NetAddress) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
setServerAddress(NetAddress.Builder) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
optional .alluxio.grpc.NetAddress serverAddress = 2;
setServerInfo(int, QuorumServerInfo) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
setServerInfo(int, QuorumServerInfo.Builder) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
setServerObserver(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Sets the server's Sasl stream.
setServerState(QuorumServerState) - Method in class alluxio.grpc.QuorumServerInfo.Builder
optional .alluxio.grpc.journal.QuorumServerState serverState = 2;
setServerType(FileSystemBase.ServerType) - Method in class alluxio.fsmaster.BenchStandaloneGrpcServer
 
setServiceType(ServiceType) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
The purpose of this field is to make grpc service on standby masters work without making client changes and keeps backwards compatibility.
setSetAcl(File.SetAclEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
setSetAcl(File.SetAclEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAclEntry set_acl = 31;
setSetAttribute(File.SetAttributeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
setSetAttribute(File.SetAttributeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.SetAttributeEntry set_attribute = 27;
setSetBlocks(int, long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
Overwrite the blocks list
setSetTaskPoolSizeCommand(SetTaskPoolSizeCommand) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
setSetTaskPoolSizeCommand(SetTaskPoolSizeCommand.Builder) - Method in class alluxio.grpc.JobCommand.Builder
optional .alluxio.grpc.job.SetTaskPoolSizeCommand setTaskPoolSizeCommand = 4;
setShared(boolean) - Method in class alluxio.grpc.MountPointInfo.Builder
optional bool shared = 7;
setShared(boolean) - Method in class alluxio.grpc.MountPOptions.Builder
optional bool shared = 3;
setShared(boolean) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional bool shared = 5;
setShared(boolean) - Method in class alluxio.wire.MountPointInfo
 
setShouldPersistTime(long) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setShouldPersistTime(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 should_persist_time = 27;
setShouldPersistTime(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 should_persist_time = 28;
setShowPermissions(boolean) - Method in class alluxio.wire.MasterWebUIBrowse
Sets show permissions.
setShowPermissions(boolean) - Method in class alluxio.wire.MasterWebUIData
Sets show permissions.
setSize(long) - Method in class alluxio.proxy.s3.ListPartsResult.Part
 
setSize(Long) - Method in class alluxio.util.UnixMountInfo.Options.Builder
 
setSize(long) - Method in class alluxio.worker.block.AllocateOptions
Sets the allocation size.
setSkewed(boolean) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional bool skewed = 4;
setSkipCache(boolean) - Method in class alluxio.master.metastore.ReadOption.Builder
Sets whether to skip caching.
setSkipIfExists(boolean) - Method in class alluxio.grpc.LoadFileRequest.Builder
optional bool skip_if_exists = 4;
setSkipIfExists(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool skipIfExists = 5;
setSkipIfExists(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional bool skip_if_exists = 10;
setSleepStepMs(long) - Method in class alluxio.time.SteppingThreadSleeper
Sets the sleep step.
setSlotIndex(int) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
Set the slot index.
setSnapshotIndex(long) - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotIndex = 2;
setSnapshotIndex(long) - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotIndex = 2;
setSnapshotInfo(SnapshotMetadata) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
setSnapshotInfo(SnapshotMetadata.Builder) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
setSnapshotInfoRequest(GetSnapshotInfoRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
setSnapshotInfoRequest(GetSnapshotInfoRequest.Builder) - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
setSnapshotInfoResponse(GetSnapshotInfoResponse) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
setSnapshotInfoResponse(GetSnapshotInfoResponse.Builder) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
setSnapshotRequest(GetSnapshotRequest) - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
setSnapshotRequest(GetSnapshotRequest.Builder) - Method in class alluxio.grpc.JournalQueryRequest.Builder
Deprecated.
setSnapshotTerm(long) - Method in class alluxio.grpc.SnapshotData.Builder
optional int64 snapshotTerm = 1;
setSnapshotTerm(long) - Method in class alluxio.grpc.SnapshotMetadata.Builder
optional int64 snapshotTerm = 1;
setSortedBy(int, SortingColumn) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
setSortedBy(int, SortingColumn.Builder) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
setSource(PropertyKey, Source) - Method in class alluxio.conf.AlluxioProperties
Sets the source for a given key.
setSource(String) - Method in class alluxio.grpc.ClientMetrics.Builder
optional string source = 1;
setSource(String) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string source = 2;
setSource(String) - Method in class alluxio.grpc.Metric.Builder
optional string source = 2;
setSource(String) - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
setSourceBytes(ByteString) - Method in class alluxio.grpc.ClientMetrics.Builder
optional string source = 1;
setSourceBytes(ByteString) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string source = 2;
setSourceBytes(ByteString) - Method in class alluxio.grpc.Metric.Builder
optional string source = 2;
setSourceHost(String) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
setSourceHost(String) - Method in class alluxio.grpc.CacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
setSourceHost(String) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
setSourceHostBytes(ByteString) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
setSourceHostBytes(ByteString) - Method in class alluxio.grpc.CacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
setSourceHostBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
TODO(calvin): source host and port should be replace with WorkerNetAddress
setSourcePort(int) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
optional int32 source_port = 3;
setSourcePort(int) - Method in class alluxio.grpc.CacheRequest.Builder
optional int32 source_port = 3;
setSourcePort(int) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
optional int32 source_port = 3;
setSpaceToReserve(long) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional int64 space_to_reserve = 10;
setSpaceToReserve(long) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int64 space_to_reserve = 4;
setSpec(String) - Method in class alluxio.grpc.table.LayoutSpec.Builder
optional string spec = 1;
setSpec(String) - Method in class alluxio.grpc.table.PartitionSpec.Builder
optional string spec = 1;
setSpecBytes(ByteString) - Method in class alluxio.grpc.table.LayoutSpec.Builder
optional string spec = 1;
setSpecBytes(ByteString) - Method in class alluxio.grpc.table.PartitionSpec.Builder
optional string spec = 1;
setSpecialCommandEnabled(boolean) - Method in class alluxio.fuse.options.FuseOptions.Builder
Enables or disabled fuse special commands.
setSrc(String) - Method in class alluxio.grpc.Route.Builder
required string src = 1;
setSrc(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string src = 1;
setSrc(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string src = 1;
setSrcBytes(ByteString) - Method in class alluxio.grpc.Route.Builder
required string src = 1;
setSrcBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required string src = 1;
setSrcBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required string src = 1;
setSrcInode(Inode) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mSrcInode field.
setSrcPath(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string srcPath = 2;
setSrcPath(AlluxioURI) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mSrcPath field.
setSrcPathBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string srcPath = 2;
setStandbyMasterInfos(MasterInfo[]) - Method in class alluxio.wire.MasterWebUIMasters
Sets standby master infos.
setStartAfter(String) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start the listing after this path.
setStartAfter(String) - Method in class alluxio.s3.ListBucketOptions
 
setStartAfterBytes(ByteString) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
Start the listing after this path.
setStartTime(long) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set started time.
setStartTime(long) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional int64 startTime = 3;
setStartTime(long) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional int64 startTime = 2;
setStartTime(long) - Method in class alluxio.grpc.ProxyStatus.Builder
optional int64 startTime = 3;
setStartTime(long) - Method in class alluxio.master.job.AbstractJob
Update start time.
setStartTime(String) - Method in class alluxio.wire.MasterInfo
 
setStartTime(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets start time.
setStartTimeMs(long) - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 startTimeMs = 5;
setStartTimeMs(long) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional int64 startTimeMs = 2;
setStartTimeMs(long) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional int64 startTimeMs = 2;
setStartTimeMs(long) - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 startTimeMs = 7;
setStartTimeMs(long) - Method in class alluxio.master.CoreMasterContext.Builder
 
setStartTimeMs(long) - Method in class alluxio.master.meta.JobMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.master.meta.MasterInfo
 
setStartTimeMs(long) - Method in class alluxio.master.meta.ProxyInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.WorkerInfo
 
setState(ValidationUtils.State) - Method in class alluxio.cli.ValidationTaskResult
Sets task state.
setState(String) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional string state = 1;
setState(String) - Method in class alluxio.grpc.MasterVersion.Builder
optional string state = 3;
setState(String) - Method in class alluxio.grpc.ProxyStatus.Builder
optional string state = 2;
setState(String) - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
setState(NodeState) - Method in class alluxio.master.AbstractPrimarySelector
 
setState(Job.PJobState) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
setState(Job.PJobState) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 2;
setState(Job.PJobState) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required .alluxio.proto.journal.PJobState state = 3;
setState(BackupState) - Method in class alluxio.wire.BackupStatus
Sets the backup state.
setState(String) - Method in class alluxio.wire.WorkerInfo
 
setStateBytes(ByteString) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional string state = 1;
setStateBytes(ByteString) - Method in class alluxio.grpc.MasterVersion.Builder
optional string state = 3;
setStateBytes(ByteString) - Method in class alluxio.grpc.ProxyStatus.Builder
optional string state = 2;
setStateBytes(ByteString) - Method in class alluxio.grpc.WorkerInfo.Builder
optional string state = 4;
setStatistics(int, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
setStatistics(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
setStatistics(int, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
setStatistics(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
setStatus(CuckooStatus) - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
Set the status of this tag position.
setStatus(Status) - Method in class alluxio.grpc.CmdSummary.Builder
optional .alluxio.grpc.job.Status status = 4;
setStatus(ConfigStatus) - Method in class alluxio.grpc.ConfigCheckReport.Builder
optional .alluxio.grpc.meta.ConfigStatus status = 3;
setStatus(TaskStatus) - Method in class alluxio.grpc.CopyResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
setStatus(PolicyStatus) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
setStatus(PolicyStatus.Builder) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
optional .alluxio.grpc.policy.PolicyStatus status = 1;
setStatus(Status) - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.Status status = 4;
setStatus(Status) - Method in class alluxio.grpc.JobProgress.Builder
optional .alluxio.grpc.job.Status status = 7;
setStatus(int, Status) - Method in class alluxio.grpc.ListAllPOptions.Builder
repeated .alluxio.grpc.job.Status status = 1;
setStatus(TaskStatus) - Method in class alluxio.grpc.LoadFileResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
setStatus(TaskStatus) - Method in class alluxio.grpc.LoadResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
setStatus(TaskStatus) - Method in class alluxio.grpc.MoveResponse.Builder
required .alluxio.grpc.block.TaskStatus status = 1;
setStatus(Status) - Method in class alluxio.grpc.StatusSummary.Builder
optional .alluxio.grpc.job.Status status = 1;
setStatus(SyncStatus) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
setStatus(SyncStatus.Builder) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus status = 2;
setStatus(Status) - Method in class alluxio.job.plan.meta.PlanInfo
Sets the status of a job.
setStatus(Status) - Method in class alluxio.job.wire.TaskInfo
 
setStatus(Status.PStatus) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
optional .alluxio.proto.status.PStatus status = 1;
setStatusSummary(List<JobServiceOutput.SerializableStatusSummary>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Set status summary.
setStopwatch(Stopwatch) - Method in class alluxio.proxy.s3.S3Handler
Set the Stopwatch object used for recording this request's latency.
setStopwatch(Stopwatch) - Method in class alluxio.worker.s3.S3NettyHandler
Set the Stopwatch object used for recording this request's latency.
setStorage(int, String) - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
setStorage(Storage) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
setStorage(Storage.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional .alluxio.grpc.table.layout.Storage storage = 5;
setStorageClass(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setStorageDirs(List<UIStorageDir>) - Method in class alluxio.wire.WorkerWebUIOverview
Sets storage dirs.
setStorageFormat(StorageFormat) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
setStorageFormat(StorageFormat.Builder) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
optional .alluxio.grpc.table.layout.StorageFormat storage_format = 1;
setStorageTierInfos(List<StorageTierInfo>) - Method in class alluxio.wire.MasterWebUIOverview
Sets storage tier infos.
setStorageTiers(int, String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
setStoreType(PageStoreType) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setStringStats(StringColumnStatsData) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
setStringStats(StringColumnStatsData.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
.alluxio.grpc.table.StringColumnStatsData string_stats = 4;
setStringType(String) - Method in class alluxio.grpc.table.Value.Builder
string string_type = 3;
setStringTypeBytes(ByteString) - Method in class alluxio.grpc.table.Value.Builder
string string_type = 3;
setStringValue(String) - Method in class alluxio.grpc.MetricValue.Builder
optional string stringValue = 2;
setStringValueBytes(ByteString) - Method in class alluxio.grpc.MetricValue.Builder
optional string stringValue = 2;
setSubject(Subject) - Method in class alluxio.grpc.GrpcChannelBuilder
Sets Subject for authentication.
setSubject(String) - Method in class alluxio.grpc.PAclEntry.Builder
optional string subject = 2;
setSubject(String) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional string subject = 2;
setSubject(String) - Method in class alluxio.security.authorization.AclEntry.Builder
Sets subject of this entry.
setSubjectBytes(ByteString) - Method in class alluxio.grpc.PAclEntry.Builder
optional string subject = 2;
setSubjectBytes(ByteString) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional string subject = 2;
setSubmissionTime(long) - Method in class alluxio.grpc.CmdSummary.Builder
optional int64 submissionTime = 5;
setSucceeded(boolean) - Method in interface alluxio.master.audit.AuditContext
Set to true if the operration associated with this AuditContext is allowed and succeeds.
setSucceeded(boolean) - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
setSucceeded(boolean) - Method in class alluxio.master.job.JobMasterAuditContext
 
setSucceeded(boolean) - Method in class alluxio.s3.S3AuditContext
 
setSuccess(boolean) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
TODO(gpang): remove in favor of status
setSuccess(boolean) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
optional bool success = 1;
setSuccess(boolean) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
TODO(gpang): remove in favor of status
setSummary(JobServiceSummary) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
setSummary(JobServiceSummary.Builder) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
optional .alluxio.grpc.job.JobServiceSummary summary = 1;
setSummaryPerStatus(int, StatusSummary) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
setSummaryPerStatus(int, StatusSummary.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
setSyncIntervalMs(long) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 syncIntervalMs = 1;
setSyncParentNextTime(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool syncParentNextTime = 5;
setSyncpointPath(String) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional string syncpoint_path = 1;
setSyncpointPath(String) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional string syncpoint_path = 1;
setSyncpointPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
optional string syncpoint_path = 1;
setSyncpointPathBytes(ByteString) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
optional string syncpoint_path = 1;
setSyncStatus(SyncStatus) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
setSyncStatus(SyncStatus.Builder) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
optional .alluxio.grpc.table.SyncStatus sync_status = 2;
setSystemStatus(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets the system status.
setTable(int, String) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
setTableInfo(TableInfo) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
setTableInfo(TableInfo.Builder) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
optional .alluxio.grpc.table.TableInfo table_info = 1;
setTableName(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string table_name = 4;
setTableName(String) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.grpc.table.TableInfo.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string table_name = 2;
setTableName(String) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
optional string table_name = 4;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.TableInfo.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
optional string table_name = 2;
setTableNameBytes(ByteString) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
optional string table_name = 2;
setTablesIgnored(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
setTablesRemoved(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
setTablesUnchanged(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
setTablesUpdated(int, String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
setTag(String) - Method in class alluxio.grpc.UfsReadOptions.Builder
required string tag = 1;
setTagBytes(ByteString) - Method in class alluxio.grpc.UfsReadOptions.Builder
required string tag = 1;
setTargetDirectory(String) - Method in class alluxio.grpc.BackupPRequest.Builder
optional string targetDirectory = 2;
setTargetDirectoryBytes(ByteString) - Method in class alluxio.grpc.BackupPRequest.Builder
optional string targetDirectory = 2;
setTargetObserver(StreamObserver<TransportMessage>) - Method in class alluxio.master.transport.GrpcMessagingConnection
Sets the stream observer for target.
setTaskArgs(ByteString) - Method in class alluxio.grpc.RunTaskCommand.Builder
optional bytes taskArgs = 4;
setTaskId(long) - Method in class alluxio.grpc.CancelTaskCommand.Builder
optional int64 taskId = 2;
setTaskId(long) - Method in class alluxio.grpc.RunTaskCommand.Builder
optional int64 taskId = 2;
setTaskId(long) - Method in class alluxio.job.wire.TaskInfo
 
setTaskInfo(long, TaskInfo) - Method in class alluxio.job.plan.meta.PlanInfo
Sets the information of a task.
setTaskInfos(int, JobInfo) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
setTaskInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
setTaskPoolSize(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 taskPoolSize = 5;
setTaskPoolSize(int) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
optional int32 taskPoolSize = 1;
setTaskPoolSize(int) - Method in class alluxio.master.job.JobMaster
 
SetTaskPoolSizeCommand - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SetTaskPoolSizeCommand
SetTaskPoolSizeCommand.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SetTaskPoolSizeCommand
SETTASKPOOLSIZECOMMAND_FIELD_NUMBER - Static variable in class alluxio.grpc.JobCommand
 
SetTaskPoolSizeCommandOrBuilder - Interface in alluxio.grpc
 
setTemporary(boolean) - Method in class alluxio.client.file.CacheContext
 
setTemporaryTokenRefreshContext(UserState) - Method in interface alluxio.underfs.UnderFileSystem
Sets the userState to UFS instance.
setTempUfsPath(String) - Method in class alluxio.master.file.meta.MutableInodeFile
 
setTempUfsPath(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string temp_ufs_path = 23;
setTempUfsPath(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string tempUfsPath = 12;
setTempUfsPath(String) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string temp_ufs_path = 11;
setTempUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string temp_ufs_path = 23;
setTempUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string tempUfsPath = 12;
setTempUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
optional string temp_ufs_path = 11;
setThreadCountIoMbps(Map<Integer, Float>) - Method in class alluxio.stress.client.ClientIOSummary
 
setThreadCountResults(Map<Integer, ClientIOTaskResult.ThreadCountResult>) - Method in class alluxio.stress.client.ClientIOTaskResult
 
setThreads(int, String) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
setThroughput(float) - Method in class alluxio.stress.common.GeneralBenchSummary
 
setThroughput(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
setThroughputPercentiles(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchSummary
 
setThroughputPercentiles(List<Long>) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
setTid(Long) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
setTier(int) - Method in class alluxio.grpc.WriteRequestCommand.Builder
This is only applicable for block write.
setTier(int) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
optional int32 tier = 3;
setTier(int) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
This is only applicable for block write.
setTier(String) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string tier = 2;
setTierAlias(String) - Method in class alluxio.grpc.BlockLocation.Builder
optional string tierAlias = 3;
setTierAlias(String) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string tierAlias = 1;
setTierAlias(String) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the alias of the target tier
setTierAlias(String) - Method in class alluxio.wire.BlockLocation
 
setTierAliasBytes(ByteString) - Method in class alluxio.grpc.BlockLocation.Builder
optional string tierAlias = 3;
setTierAliasBytes(ByteString) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
optional string tierAlias = 1;
setTierAliasBytes(ByteString) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the alias of the target tier
setTierBytes(ByteString) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional string tier = 2;
setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setTierPaths(Map<String, List<String>>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setTiers(int, long) - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
setTimeExpression(String) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string timeExpression = 4;
setTimeExpressionBytes(ByteString) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
optional string timeExpression = 4;
setTimeout(long) - Method in class alluxio.network.netty.NettyRPCContext
 
setTimeoutDuration(long) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setTimeoutMs(long) - Method in class alluxio.util.WaitForOptions
 
setTimeoutThreads(int) - Method in class alluxio.client.file.cache.store.PageStoreOptions
 
setTimeSeriesMetrics(List<TimeSeries>) - Method in class alluxio.wire.MasterWebUIMetrics
 
setTimeToFirstBytePerThread(Map<Integer, Map<String, SummaryStatistics>>) - Method in class alluxio.stress.client.ClientIOTaskResult
 
setTitle(List<String>) - Method in class alluxio.stress.graph.Graph
 
setTotal(long) - Method in class alluxio.wire.Capacity
 
setTotalBytesReadDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read from domain socket.
setTotalBytesReadDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read domain socket throughput.
setTotalBytesReadRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read remote.
setTotalBytesReadRemoteThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read remote throughput.
setTotalBytesReadUfs(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read ufs.
setTotalBytesReadUfsThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read ufs throughput.
setTotalBytesWrittenDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written through domain socket.
setTotalBytesWrittenDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written domain socket throughput.
setTotalBytesWrittenRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written remote.
setTotalBytesWrittenRemoteThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written remote throughput.
setTotalBytesWrittenUfs(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written ufs.
setTotalBytesWrittenUfsThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written ufs throughput.
setTotalCapacityOnTiers(Map<String, Long>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Get capacity by tiers.
setTotalListings(long) - Method in class alluxio.master.file.contexts.ListStatusContext
Set the total number of listings in this call, this should be -1 if a recursive listing.
setTotalPath(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets total path.
setTransferId(String) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
required string transferId = 1;
setTransferId(String) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
required string transferId = 1;
setTransferIdBytes(ByteString) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
required string transferId = 1;
setTransferIdBytes(ByteString) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
required string transferId = 1;
setTransformations(int, Transformation) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
setTransformations(int, Transformation.Builder) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
setTransMsg(TransferLeaderMessage) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
setTransMsg(TransferLeaderMessage.Builder) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
required .alluxio.grpc.journal.TransferLeaderMessage transMsg = 1;
setTs(long) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
the timestamp in nanoseconds when this FileStatus is refreshed
setTtl(FileSystem, AlluxioURI, long, TtlAction) - Static method in class alluxio.cli.fs.command.FileSystemCommandUtils
Sets a new TTL value or unsets an existing TTL value for file at path.
setTtl(long) - Method in class alluxio.grpc.FileInfo.Builder
optional int64 ttl = 15;
setTtl(long) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional int64 ttl = 2;
setTtl(long) - Method in class alluxio.master.file.meta.MutableInode
 
setTtl(long) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional int64 ttl = 13;
setTtl(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional int64 ttl = 13;
setTtl(long) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional int64 ttl = 4;
setTtl(long) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional int64 ttl = 12;
setTtl(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional int64 ttl = 4;
setTtl(long) - Method in class alluxio.wire.FileInfo
 
setTtlAction(TtlAction) - Method in class alluxio.grpc.FileInfo.Builder
optional .alluxio.grpc.TtlAction ttlAction = 22;
setTtlAction(TtlAction) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
optional .alluxio.grpc.TtlAction ttlAction = 3;
setTtlAction(TtlAction) - Method in class alluxio.master.file.meta.MutableInode
 
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 14 [default = DELETE];
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 17 [default = DELETE];
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 9 [default = DELETE];
setTtlAction(File.PTtlAction) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.PTtlAction ttlAction = 13 [default = DELETE];
setTtlAction(TtlAction) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional .alluxio.grpc.TtlAction ttl_action = 5;
setTtlAction(TtlAction) - Method in class alluxio.wire.FileInfo
 
setTtlCheckIntervalSeconds(long) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setTtlEnabled(boolean) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setTtlThresholdSeconds(long) - Method in class alluxio.client.file.cache.CacheManagerOptions
 
setTxId(long) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
optional int64 tx_id = 2;
setType(String) - Method in class alluxio.grpc.JobDescription.Builder
required string type = 1;
setType(JobType) - Method in class alluxio.grpc.JobInfo.Builder
optional .alluxio.grpc.job.JobType type = 8;
setType(PAclEntryType) - Method in class alluxio.grpc.PAclEntry.Builder
optional .alluxio.grpc.file.PAclEntryType type = 1;
setType(String) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string type = 3;
setType(TableInfo.TableType) - Method in class alluxio.grpc.table.TableInfo.Builder
optional .alluxio.grpc.table.TableInfo.TableType type = 3;
setType(RequestType) - Method in class alluxio.grpc.WriteRequestCommand.Builder
optional .alluxio.grpc.block.RequestType type = 1;
setType(String) - Method in class alluxio.job.JobDescription.Builder
set job type.
setType(Protocol.ReadResponse.Type) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
optional .alluxio.proto.dataserver.ReadResponse.Type type = 1;
setType(Protocol.RequestType) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
optional .alluxio.proto.dataserver.RequestType type = 1;
setType(Acl.AclEntryType) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
optional .alluxio.proto.shared.AclEntryType type = 1;
setType(AclEntryType) - Method in class alluxio.security.authorization.AclEntry.Builder
Sets the type of the entry.
setTypeBytes(ByteString) - Method in class alluxio.grpc.JobDescription.Builder
required string type = 1;
setTypeBytes(ByteString) - Method in class alluxio.grpc.table.FieldSchema.Builder
optional string type = 3;
setUdbConnectionUri(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
setUdbConnectionUriBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_connection_uri = 2;
setUdbDbName(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
setUdbDbNameBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_db_name = 3;
setUdbType(String) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
setUdbTypeBytes(ByteString) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
optional string udb_type = 1;
setUfsCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
 
setUfsCapacityBytes(long) - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsCapacityBytes = 3 [default = -1];
setUfsCapacityBytes(long) - Method in class alluxio.wire.MountPointInfo
 
setUfsFallbackEnabled(boolean) - Method in class alluxio.client.file.DoraCacheFileSystem
Dora Cache file system implementation.
setUfsFallbackEnabled(boolean) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
setUfsFileStatus(UfsFileStatus) - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
setUfsFileStatus(UfsFileStatus.Builder) - Method in class alluxio.grpc.UfsStatus.Builder
optional .alluxio.grpc.block.UfsFileStatus ufs_file_status = 100;
setUfsFileSystemOptions(UfsFileSystemOptions) - Method in class alluxio.client.file.options.FileSystemOptions.Builder
 
setUfsFingerprint(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsFingerprint = 26;
setUfsFingerprint(String) - Method in class alluxio.master.file.contexts.SetAttributeContext
Sets ufs fingerprint.
setUfsFingerprint(String) - Method in class alluxio.master.file.meta.MutableInode
 
setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
setUfsFingerprint(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string ufs_fingerprint = 15;
setUfsFingerprint(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string ufs_fingerprint = 11;
setUfsFingerprint(String) - Method in class alluxio.wire.FileInfo
 
setUfsFingerprintBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsFingerprint = 26;
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
optional string ufs_fingerprint = 5;
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
optional string ufs_fingerprint = 18;
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
optional string ufs_fingerprint = 10;
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional string ufs_fingerprint = 15;
setUfsFingerprintBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
optional string ufs_fingerprint = 11;
setUfsFullPath(String) - Method in class alluxio.grpc.UfsStatus.Builder
optional string ufs_full_path = 8;
setUfsFullPath(AlluxioURI) - Method in class alluxio.underfs.UfsStatus
 
setUfsFullPathBytes(ByteString) - Method in class alluxio.grpc.UfsStatus.Builder
optional string ufs_full_path = 8;
setUfsInfo(UfsInfo) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
setUfsInfo(UfsInfo.Builder) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
optional .alluxio.grpc.file.UfsInfo ufsInfo = 1;
setUfsLength(long) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
optional int64 ufsLength = 1;
setUfsLocations(int, WorkerNetAddress) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
setUfsLocations(int, WorkerNetAddress.Builder) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
setUfsLocations(List<String>) - Method in class alluxio.wire.FileBlockInfo
 
setUfsManager(MasterUfsManager) - Method in class alluxio.master.CoreMasterContext.Builder
 
setUfsMode(UfsPMode) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
optional .alluxio.grpc.file.UfsPMode ufsMode = 1;
setUfsMode(File.UfsMode) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional .alluxio.proto.journal.UfsMode ufsMode = 2 [default = READ_WRITE];
setUfsMode(Supplier<JournalContext>, AlluxioURI, UfsMode) - Method in class alluxio.underfs.MasterUfsManager
Set the operation mode the given physical ufs.
setUfsOps(Map<String, Map<String, Long>>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs ops.
setUfsOpsSaved(Map<String, Map<String, Long>>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs saved ops.
setUfsPath(String) - Method in class alluxio.client.file.options.OutStreamOptions
 
setUfsPath(String) - Method in class alluxio.grpc.Block.Builder
optional string ufs_path = 3;
setUfsPath(String) - Method in class alluxio.grpc.File.Builder
optional string ufs_path = 2;
setUfsPath(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsPath = 4;
setUfsPath(String) - Method in class alluxio.grpc.MountPRequest.Builder
the path of the under file system
setUfsPath(String) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
the ufs path
setUfsPath(String) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
setUfsPath(String) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
setUfsPath(String) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
setUfsPath(String) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
setUfsPath(String) - Method in class alluxio.wire.FileInfo
 
setUfsPathBytes(ByteString) - Method in class alluxio.grpc.Block.Builder
optional string ufs_path = 3;
setUfsPathBytes(ByteString) - Method in class alluxio.grpc.File.Builder
optional string ufs_path = 2;
setUfsPathBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsPath = 4;
setUfsPathBytes(ByteString) - Method in class alluxio.grpc.MountPRequest.Builder
the path of the under file system
setUfsPathBytes(ByteString) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
the ufs path
setUfsPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
optional string ufs_path = 1;
setUfsPathBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
optional string ufs_path = 1;
setUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
optional string ufs_path = 2;
setUfsPathBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
optional string ufsPath = 1;
setUfsReadOptions(UfsReadOptions) - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
setUfsReadOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
setUfsReadOptions(UfsReadOptions) - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
setUfsReadOptions(UfsReadOptions.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
optional .alluxio.grpc.block.UfsReadOptions ufs_read_options = 2;
setUfsReadSize(Map<String, String>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs read size.
setUfsReadWorkerLocation(WorkerNetAddress) - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
setUfsReadWorkerLocation(WorkerNetAddress.Builder) - Method in class alluxio.grpc.OpenFilePOptions.Builder
If specified and the blocks are not cached in any worker, the data will be read and cached to the certain worker.
setUfsResource(CloseableResource<UnderFileSystem>) - Method in class alluxio.worker.grpc.UfsFileWriteRequestContext
 
setUfsStatus(UfsStatus) - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
setUfsStatus(UfsStatus.Builder) - Method in class alluxio.grpc.LoadFileFailure.Builder
optional .alluxio.grpc.block.UfsStatus ufs_status = 1;
setUfsStatus(int, UfsStatus) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
setUfsStatus(int, UfsStatus.Builder) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
setUfsStatus(UfsStatus) - Method in class alluxio.master.file.contexts.CompleteFileContext
Sets ufs status.
setUfsStatus(UfsStatus) - Method in class alluxio.master.file.contexts.CreateDirectoryContext
Sets UfsStatus for the directory.
setUfsStatus(UfsStatus) - Method in class alluxio.master.file.contexts.LoadMetadataContext
Sets UfsStatus for the directory.
setUfsStringLocations(int, String) - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
setUfsType(String) - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsType = 35;
setUfsType(String) - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
setUfsType(String) - Method in class alluxio.wire.FileInfo
 
setUfsType(String) - Method in class alluxio.wire.MountPointInfo
 
setUfsTypeBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
optional string ufsType = 35;
setUfsTypeBytes(ByteString) - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsType = 2;
setUfsUri(String) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
required string ufsUri = 1;
setUfsUri(String) - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsUri = 1;
setUfsUri(String) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
optional string ufsUri = 1;
setUfsUri(String) - Method in class alluxio.wire.MountPointInfo
 
setUfsUriBytes(ByteString) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
required string ufsUri = 1;
setUfsUriBytes(ByteString) - Method in class alluxio.grpc.MountPointInfo.Builder
optional string ufsUri = 1;
setUfsUriBytes(ByteString) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
optional string ufsUri = 1;
setUfsUsedBytes(long) - Method in class alluxio.grpc.MountPointInfo.Builder
optional int64 ufsUsedBytes = 4 [default = -1];
setUfsUsedBytes(long) - Method in class alluxio.wire.MountPointInfo
 
setUfsWriteSize(Map<String, String>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs write size.
setUgi(String) - Method in class alluxio.master.file.FileSystemMasterAuditContext
Sets mUgi field.
setUgi(String) - Method in class alluxio.master.job.JobMasterAuditContext
Sets mUgi field.
setUgi(String) - Method in class alluxio.s3.S3AuditContext
Sets mUgi field.
setUnchecked(boolean) - Method in class alluxio.grpc.DeletePOptions.Builder
optional bool unchecked = 3;
setUnderFileSystem(UnderFileSystem) - Method in class alluxio.worker.netty.UfsFileWriteRequestContext
 
setUnfinishedTasks(int) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int32 unfinishedTasks = 7;
setUniqueBlockCount(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets unique block count.
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ActionInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupPStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Block.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockIdList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockLocation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.BuildVersion.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CacheRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CacheResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CheckResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Chunk.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ClientMetrics.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdProgress.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CmdSummary.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Command.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigProperties.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ConfigProperty.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CopyResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DeletePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ErrorInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.File.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileFailure.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.FsOpPId.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobCommand.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobDescription.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobProgress.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobUnused.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LoadResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MasterVersion.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Metric.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MetricValue.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPointInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MountPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.MoveResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NetAddress.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PAcl.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PAclEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PersistFile.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PMode.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PolicyInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.PolicyStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ProxyStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReadRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReadResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterCommand.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RenamePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RetryInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.Route.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RouteFailure.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SaslMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SnapshotData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StatusSummary.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.StorageList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.SubmitResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Constraint.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Database.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Date.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Decimal.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Domain.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Layout.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Partition.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Range.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.RangeSet.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Schema.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TableInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Transformation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.table.Value.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TierList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TransportMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UfsStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.grpc.WriteResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
setUnscaled(ByteString) - Method in class alluxio.grpc.table.Decimal.Builder
required bytes unscaled = 2;
setUnused0(int, JobUnused) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
setUnused0(int, JobUnused.Builder) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
setUnused1(String) - Method in class alluxio.grpc.JobInfo.Builder
formerly result
setUnused1Bytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
formerly result
setup() - Method in class alluxio.dora.meta.DoraMetaBench.Db
 
setup() - Method in class alluxio.fsmaster.FileSystemBench.AlluxioBenchThreadState
 
setup(FileSystemBench.FileSystem, ThreadParams) - Method in class alluxio.fsmaster.FileSystemBench.AsyncBenchThreadState
 
setup(FileSystemBench.FileSystem, ThreadParams) - Method in class alluxio.fsmaster.FileSystemBench.BlockingBenchThreadState
 
setup() - Method in class alluxio.fsmaster.FileSystemBench.FileSystem
 
setup() - Method in class alluxio.fsmaster.FileSystemBench.HadoopBenchThreadState
 
setup(FileSystemBench.FileSystem) - Method in class alluxio.fsmaster.FileSystemBench.ThreadState
 
setup() - Method in class alluxio.fsmaster.FileSystemMasterBench.FileSystem
 
setup() - Method in class alluxio.fsmaster.FileSystemMasterBench.ThreadState
 
setup() - Method in class alluxio.inode.InodeBenchRead.Db
 
setup() - Method in class alluxio.inode.InodeBenchWrite.Db
 
setup(InodeBenchWrite.Db) - Method in class alluxio.inode.InodeBenchWrite.ThreadState
 
setup() - Method in class alluxio.inode.RocksBenchRead.Db
 
setup() - Method in class alluxio.inode.RocksBenchRead.ThreadState
 
setup() - Method in class alluxio.inode.RocksBenchReadWrite.Db
 
setup(RocksBenchReadWrite.Db, ThreadParams) - Method in class alluxio.inode.RocksBenchReadWrite.ThreadState
 
setup() - Method in class alluxio.inode.RocksBenchWrite.Db
 
setup(ThreadParams) - Method in class alluxio.inode.RocksBenchWrite.ThreadState
 
setup() - Method in class alluxio.invalidation.cache.InvalidationSyncCacheBench.ThreadState
 
setup() - Method in class alluxio.snapshot.SnapshotBench.Snapshot
 
setUpdateCheckEnabled(boolean) - Method in class alluxio.fuse.options.FuseOptions.Builder
Enables or disables update check.
setUpdateInode(File.UpdateInodeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
setUpdateInode(File.UpdateInodeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeEntry update_inode = 35;
setUpdateInodeDirectory(File.UpdateInodeDirectoryEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
setUpdateInodeDirectory(File.UpdateInodeDirectoryEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeDirectoryEntry update_inode_directory = 36;
setUpdateInodeFile(File.UpdateInodeFileEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
setUpdateInodeFile(File.UpdateInodeFileEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateInodeFileEntry update_inode_file = 37;
setUpdateLastAccessTime(boolean) - Method in class alluxio.grpc.OpenFilePOptions.Builder
optional bool updateLastAccessTime = 4 [default = true];
setUpdateTimestamps(boolean) - Method in class alluxio.grpc.GetStatusPOptions.Builder
optional bool updateTimestamps = 4 [default = true];
setUpdateUfsMode(File.UpdateUfsModeEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
setUpdateUfsMode(File.UpdateUfsModeEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
optional .alluxio.proto.journal.UpdateUfsModeEntry update_ufs_mode = 30;
setupFuseFileSystem(AlluxioJniFuseFileSystem) - Method in class alluxio.fuse.AlluxioFuse
Set up the FUSE file system AlluxioJniFuseFileSystem before mounting.
setUploadId(String) - Method in class alluxio.proxy.s3.InitiateMultipartUploadResult
 
setUploadId(String) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult.Upload
 
setUploadId(String) - Method in class alluxio.proxy.s3.ListPartsResult
 
setUploads(List<ListMultipartUploadsResult.Upload>) - Method in class alluxio.proxy.s3.ListMultipartUploadsResult
 
setupTest() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Sets up corresponding directories for tests.
setUptime(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets uptime.
setUptimeDuration(long) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set time running.
setUpTimeMs(long) - Method in class alluxio.grpc.MasterInfo.Builder
optional int64 upTimeMs = 6;
setUptimeMs(long) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setupTrial() - Method in class alluxio.invalidation.cache.InvalidationSyncCacheBench.FileStructure
 
setUri(String) - Method in class alluxio.grpc.UfsInfo.Builder
optional string uri = 1;
setUri(AlluxioURI) - Method in class alluxio.wire.UfsInfo
 
setUriBytes(ByteString) - Method in class alluxio.grpc.UfsInfo.Builder
optional string uri = 1;
setUriValidationEnabled(boolean) - Method in class alluxio.ClientContext
 
setUsageOnTiers(List<UIUsageOnTier>) - Method in class alluxio.wire.WorkerWebUIOverview
Sets usage on tiers.
setUsed(long) - Method in class alluxio.wire.Capacity
 
setUsedBytes(long) - Method in class alluxio.grpc.BlockMasterInfo.Builder
optional int64 usedBytes = 6;
setUsedBytes(long) - Method in class alluxio.grpc.WorkerInfo.Builder
optional int64 usedBytes = 6;
setUsedBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setUsedBytes(long) - Method in class alluxio.wire.WorkerInfo
 
setUsedBytes(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets used bytes.
setUsedBytesOnTier(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the space used in bytes on the target tier
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
 
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
 
setUsedCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets used capacity.
setUsedCapacityOnTiers(Map<String, Long>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set used capacity by tiers.
setUseMultipartUpload(boolean) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional bool useMultipartUpload = 17;
setUser(String) - Method in class alluxio.grpc.UfsReadOptions.Builder
optional string user = 4;
setUser(String) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
setUser(String) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional string user = 6;
setUser(String) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional string user = 5;
setUser(String) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional string user = 6;
setUserActions(int, Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
setUserActions(int, Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
setUseRaftJournal(boolean) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set if Alluxio uses raft journal.
setUserBytes(ByteString) - Method in class alluxio.grpc.UfsReadOptions.Builder
optional string user = 4;
setUserBytes(ByteString) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
The client does not need to set this.
setUserBytes(ByteString) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
optional string user = 6;
setUserBytes(ByteString) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
optional string user = 5;
setUserBytes(ByteString) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
optional string user = 6;
setUseReservedSpace(boolean) - Method in class alluxio.worker.block.AllocateOptions
Sets value for whether this allocation can use reserved space.
setUserGroup(AlluxioURI, long, long) - Method in interface alluxio.fuse.auth.AuthPolicy
Sets user and group based on user group input.
setUserGroup(AlluxioURI, long, long) - Method in class alluxio.fuse.auth.CustomAuthPolicy
 
setUserGroup(AlluxioURI, long, long) - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
setUserGroupIfNeeded(AlluxioURI) - Method in interface alluxio.fuse.auth.AuthPolicy
Sets user and group based on authentication policy.
setUserGroupIfNeeded(AlluxioURI) - Method in class alluxio.fuse.auth.CustomAuthPolicy
 
setUserGroupIfNeeded(AlluxioURI) - Method in class alluxio.fuse.auth.LaunchUserGroupAuthPolicy
 
setUserGroupIfNeeded(AlluxioURI) - Method in class alluxio.fuse.auth.SystemUserGroupAuthPolicy
 
setUserState(UserState) - Method in class alluxio.master.CoreMasterContext.Builder
 
setUseZookeeper(boolean) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set if zookeeper is running.
setUuid(String) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional string uuid = 3;
setUuid(String) - Method in class alluxio.grpc.CreateFilePResponse.Builder
uuid of its open file handle
setUuidBytes(ByteString) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
optional string uuid = 3;
setUuidBytes(ByteString) - Method in class alluxio.grpc.CreateFilePResponse.Builder
uuid of its open file handle
setValue(String) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
setValue(BlockIdList) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
setValue(BlockIdList.Builder) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
optional .alluxio.grpc.block.BlockIdList value = 2;
setValue(double) - Method in class alluxio.grpc.Metric.Builder
optional double value = 4;
setValue(String) - Method in class alluxio.master.meta.checkconf.ConfigRecord
 
setValue(double) - Method in class alluxio.metrics.Metric
Set the metric value.
setValue(String) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
setValue(String) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string value = 3;
setValueBytes(ByteString) - Method in class alluxio.grpc.ConfigProperty.Builder
optional string value = 3;
setValueBytes(ByteString) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
optional string value = 2;
setValueBytes(ByteString) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
required string value = 3;
setValues(int, String) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
setValues(int, String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
setValues(Map<Optional<String>, List<String>>) - Method in class alluxio.wire.InconsistentProperty
 
setValueValidationFunction(Function<Object, Boolean>) - Method in class alluxio.conf.PropertyKey.Builder
 
setVerbose(boolean) - Method in class alluxio.grpc.JobProgressPOptions.Builder
optional bool verbose = 2;
setVerificationEnabled(boolean) - Method in class alluxio.master.job.CopyJob
Enable verification.
setVerificationEnabled(boolean) - Method in class alluxio.master.job.LoadJob
Enable verification.
setVerificationEnabled(boolean) - Method in class alluxio.master.job.MoveJob
Enable verification.
setVerify(boolean) - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional bool verify = 2;
setVerify(boolean) - Method in class alluxio.grpc.LoadJobPOptions.Builder
optional bool verify = 2;
setVerify(boolean) - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional bool verify = 2;
setVerify(boolean) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
required bool verify = 5;
setVerify(boolean) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
required bool verify = 4;
setVerify(boolean) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
required bool verify = 5;
setVersion(String) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set Alluxio version.
setVersion(String) - Method in class alluxio.grpc.BuildVersion.Builder
the project version
setVersion(long) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
optional int64 version = 1;
setVersion(BuildVersion) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.JobMasterStatus.Builder
optional .alluxio.grpc.BuildVersion version = 4;
setVersion(BuildVersion) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional .alluxio.grpc.BuildVersion version = 8;
setVersion(String) - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
setVersion(String) - Method in class alluxio.grpc.MasterVersion.Builder
optional string version = 2;
setVersion(BuildVersion) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 3;
setVersion(BuildVersion) - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.ProxyStatus.Builder
optional .alluxio.grpc.BuildVersion version = 5;
setVersion(BuildVersion) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
optional .alluxio.grpc.BuildVersion version = 4;
setVersion(BuildVersion) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
setVersion(BuildVersion.Builder) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.BuildVersion version = 3;
setVersion(String) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string version = 4;
setVersion(long) - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version = 4;
setVersion(long) - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version = 10;
setVersion(int) - Method in class alluxio.grpc.WorkerIdentity.Builder
version of the definition of the opaque identifier
setVersion(BuildVersion) - Method in class alluxio.master.meta.JobMasterInfo
 
setVersion(String) - Method in class alluxio.master.meta.MasterInfo
 
setVersion(String) - Method in class alluxio.master.meta.ProxyInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioProxyInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setVersion(String) - Method in class alluxio.wire.MasterInfo
 
setVersion(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets version.
setVersion(String) - Method in class alluxio.wire.WorkerInfo
 
setVersion(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets version.
setVersionBytes(ByteString) - Method in class alluxio.grpc.BuildVersion.Builder
the project version
setVersionBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
optional string version = 7;
setVersionBytes(ByteString) - Method in class alluxio.grpc.MasterVersion.Builder
optional string version = 2;
setVersionBytes(ByteString) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
optional string version = 4;
setVersionCreationTime(long) - Method in class alluxio.grpc.table.Partition.Builder
optional int64 version_creation_time = 5;
setVersionCreationTime(long) - Method in class alluxio.grpc.table.TableInfo.Builder
optional int64 version_creation_time = 11;
setVersionId(String) - Method in class alluxio.s3.DeleteObjectsResult.DeletedObject
Sets the version id of deleted object.
setVersionId(String) - Method in class alluxio.s3.DeleteObjectsResult.ErrorObject
Sets the version id.
setViewingOffset(long) - Method in class alluxio.wire.MasterWebUIBrowse
Sets viewing offset.
setViewingOffset(long) - Method in class alluxio.wire.MasterWebUILogs
Sets viewing offset.
setViewingOffset(long) - Method in class alluxio.wire.WorkerWebUILogs
Sets viewing offset.
setWebFileInfoEnabled(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets web file info enabled.
setWebFileInfoEnabled(boolean) - Method in class alluxio.wire.WorkerWebUIInit
Sets web file info enabled.
setWebPort(int) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set web port.
setWebPort(int) - Method in class alluxio.grpc.MasterInfo.Builder
optional int32 webPort = 8;
setWebPort(int) - Method in class alluxio.grpc.WorkerNetAddress.Builder
optional int32 webPort = 4;
setWebPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setWebServer(WebServer) - Method in class alluxio.worker.AlluxioWorkerProcess
 
setWhiteList(boolean) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
optional bool white_list = 2;
setWhitelist(List<String>) - Method in class alluxio.wire.MasterWebUIConfiguration
Sets whitelist.
setWhitelist(List<String>) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets whitelist.
setWid(Long) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
setWorkerAddress(WorkerNetAddress) - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
setWorkerAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.BlockLocation.Builder
optional .alluxio.grpc.WorkerNetAddress workerAddress = 2;
setWorkerAddress(WorkerNetAddress) - Method in class alluxio.wire.BlockLocation
 
setWorkerAddresses(int, NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
setWorkerAddresses(int, NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
setWorkerAssignPolicy(WorkerAssignPolicy) - Method in class alluxio.master.job.AbstractJob
Sets the worker assign policy.
setWorkerCapacityFreePercentage(long) - Method in class alluxio.wire.WorkerWebUIMetrics
Sets worker capacity free percentage.
setWorkerCapacityUsedPercentage(long) - Method in class alluxio.wire.WorkerWebUIMetrics
Sets worker capacity used percentage.
setWorkerHealth(List<JobServiceOutput.SerializableWorkerHealth>) - Method in class alluxio.cli.fsadmin.report.JobServiceOutput
Set worker health info.
setWorkerHealths(int, JobWorkerHealth) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
setWorkerHealths(int, JobWorkerHealth.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
setWorkerHost(String) - Method in class alluxio.grpc.JobInfo.Builder
optional string workerHost = 12;
setWorkerHost(String) - Method in class alluxio.job.wire.TaskInfo
 
setWorkerHostBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
optional string workerHost = 12;
setWorkerHostname(String) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
required string workerHostname = 1;
setWorkerHostname(String) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
required string workerHostname = 1;
setWorkerHostnameBytes(ByteString) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
required string workerHostname = 1;
setWorkerHostnameBytes(ByteString) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
required string workerHostname = 1;
setWorkerId(long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the id of the worker
setWorkerId(long) - Method in class alluxio.grpc.BlockLocation.Builder
optional int64 workerId = 1;
setWorkerId(long) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
the id of the worker
setWorkerId(long) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the id of the worker
setWorkerId(long) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
optional int64 workerId = 1;
setWorkerId(long) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
optional int64 workerId = 1;
setWorkerId(long) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
optional int64 workerId = 1;
setWorkerId(long) - Method in class alluxio.grpc.JobWorkerHealth.Builder
optional int64 workerId = 1;
setWorkerId(long) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
optional int64 workerId = 1;
setWorkerId(long) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the id of the worker
setWorkerId(long) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
optional int64 worker_id = 1;
setWorkerId(long) - Method in class alluxio.wire.BlockLocation
 
setWorkerInfo(UIWorkerInfo) - Method in class alluxio.wire.WorkerWebUIOverview
Sets worker info.
setWorkerInfos(int, WorkerInfo) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
setWorkerInfos(int, WorkerInfo.Builder) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
setWorkerLocation(WorkerNetAddress) - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
setWorkerLocation(WorkerNetAddress.Builder) - Method in class alluxio.grpc.CreateFilePOptions.Builder
If specified, the data will be written to the certain worker
setWorkerLostStorageInfo(int, WorkerLostStorageInfo) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
setWorkerLostStorageInfo(int, WorkerLostStorageInfo.Builder) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
setWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
setWorkerNetAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
the worker network address
setWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
setWorkerNetAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
the worker network address
setWorkerNetAddress(WorkerNetAddress) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
setWorkerNetAddress(WorkerNetAddress.Builder) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
optional .alluxio.grpc.WorkerNetAddress workerNetAddress = 1;
setWorkerPort(int) - Method in class alluxio.wire.MasterWebUIInit
Sets worker port.
setWorkerProperties(Map<Integer, Map<PropertyKey, String>>) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
Sets worker specific properties.
setWorkerRange(GetWorkerReportOptions.WorkerRange) - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
setWorkerRange(WorkerRange) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
optional .alluxio.grpc.block.WorkerRange workerRange = 3;
setWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setWorkerWebPort(long) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
optional int64 workerWebPort = 2;
setWorkerWebPort(long) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
optional int64 workerWebPort = 2;
setWorkingDirectory(Path) - Method in class alluxio.hadoop.AbstractFileSystem
 
setWorkingDirectory(Path) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
setWriteOffset(long) - Method in class alluxio.fuse.OpenFileEntry
Sets the offset of the next write.
setWriteOptions(WriteOptions) - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
setWriteOptions(WriteOptions.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
setWriteOptions(WriteOptions) - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
setWriteOptions(WriteOptions.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
required .alluxio.grpc.block.WriteOptions write_options = 3;
setWriteSpeedStat(IOTaskSummary.SpeedStat) - Method in class alluxio.stress.worker.IOTaskSummary
 
setWriteTier(int) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the write tier.
setWriteTier(int) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional int32 writeTier = 7;
setWriteType(WriteType) - Method in class alluxio.client.file.options.OutStreamOptions
Sets the WriteType.
setWriteType(WritePType) - Method in class alluxio.grpc.CopyJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
setWriteType(WritePType) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 4 [default = CACHE_THROUGH];
setWriteType(WritePType) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 8 [default = CACHE_THROUGH];
setWriteType(WritePType) - Method in class alluxio.grpc.MoveJobPOptions.Builder
optional .alluxio.grpc.file.WritePType writeType = 5 [default = CACHE_THROUGH];
setWriteType(WritePType) - Method in class alluxio.grpc.WriteOptions.Builder
optional .alluxio.grpc.file.WritePType write_type = 2 [default = CACHE_THROUGH];
setWriteType(WriteType) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setXAttr(Map<String, byte[]>) - Method in class alluxio.master.file.contexts.CreatePathContext
 
setXAttr(Map<String, byte[]>) - Method in class alluxio.master.file.meta.MutableInode
 
setXAttr(Map<String, byte[]>, File.XAttrUpdateStrategy) - Method in class alluxio.master.file.meta.MutableInode
 
setXAttr(Map<String, byte[]>) - Method in class alluxio.wire.FileInfo
 
setxattrCallback(String, String, ByteBuffer, long, int) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
setXattrPropStrat(XAttrPropagationStrategy) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 7 [default = NEW_PATHS];
setXattrPropStrat(XAttrPropagationStrategy) - Method in class alluxio.grpc.CreateFilePOptions.Builder
optional .alluxio.grpc.file.XAttrPropagationStrategy xattrPropStrat = 12 [default = NEW_PATHS];
setXattrUpdateStrategy(File.XAttrUpdateStrategy) - Method in class alluxio.grpc.SetAttributePOptions.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xattrUpdateStrategy = 12;
setXAttrUpdateStrategy(File.XAttrUpdateStrategy) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
optional .alluxio.proto.journal.XAttrUpdateStrategy xAttr_update_strategy = 20 [default = TRUNCATE];
setZookeeperAddress(List<String>) - Method in class alluxio.cli.fsadmin.report.SummaryOutput
Set zookeeper address.
setZookeeperAddresses(int, String) - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
sFileSystemContextFactory - Static variable in class alluxio.client.file.FileSystemContext
 
ShadowCacheManager - Interface in alluxio.client.file.cache
The interface represents a shadow cache which supports put/read/delete/aging operations.
ShadowCacheType - Enum in alluxio.client.file.cache
This represents the different shadow cache implementations that can be instantiated.
SHARED_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
SHARED_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPOptions
 
SHARED_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
SharedGrpcDataReader - Class in alluxio.client.block.stream
A shared gRPC data reader that cache blocks data for multi-thread accessing.
SharedGrpcDataReader(ReadRequest, BufferCachingGrpcDataReader) - Constructor for class alluxio.client.block.stream.SharedGrpcDataReader
Creates an instance of SharedGrpcDataReader.
SharedGrpcDataReader.Factory - Class in alluxio.client.block.stream
Factory class to create SharedGrpcDataReaders.
ShellBasedUnixGroupsMapping - Class in alluxio.security.group.provider
A simple shell-based implementation of GroupMappingService that exec's the groups shell command to fetch the group memberships of a given user.
ShellBasedUnixGroupsMapping() - Constructor for class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
Constructs a new ShellBasedUnixGroupsMapping.
ShellCommand - Class in alluxio.shell
Object representation of a shell command.
ShellCommand(String[]) - Constructor for class alluxio.shell.ShellCommand
Creates a ShellCommand object with the command to exec.
ShellUtils - Class in alluxio.util
A utility class for running Unix commands.
ShellUtils.ExitCodeException - Exception in alluxio.util
This is an IOException with exit code added.
SHOULD_NOT_SYNC - Static variable in class alluxio.master.file.meta.SyncCheck
Sync is not needed, with no last sync time.
SHOULD_PERSIST_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
SHOULD_PERSIST_TIME_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
SHOULD_SYNC - Static variable in class alluxio.master.file.meta.SyncCheck
Sync is needed.
shouldAbort(int) - Method in class alluxio.rocks.RocksStore
Used by ongoing r/w operations to check if the operation needs to abort and yield to the RocksDB shutdown.
shouldGc(DynamicResourcePool<BlockMasterClient>.ResourceInternal<BlockMasterClient>) - Method in class alluxio.client.block.BlockMasterClientPool
 
shouldGc(DynamicResourcePool<BlockWorkerClient>.ResourceInternal<BlockWorkerClient>) - Method in class alluxio.client.block.stream.BlockWorkerClientPool
 
shouldGc(DynamicResourcePool<FileSystemMasterClient>.ResourceInternal<FileSystemMasterClient>) - Method in class alluxio.client.file.FileSystemMasterClientPool
 
shouldGc(DynamicResourcePool<Channel>.ResourceInternal<Channel>) - Method in class alluxio.network.netty.NettyChannelPool
 
shouldGc(DynamicResourcePool<T>.ResourceInternal<T>) - Method in class alluxio.resource.DynamicResourcePool
 
shouldNotSyncWithTime(long) - Static method in class alluxio.master.file.meta.SyncCheck
Create a SyncCheck object indicating a sync is not needed due to a recent sync.
shouldSkipCache() - Method in class alluxio.master.metastore.ReadOption
 
shouldSync() - Method in class alluxio.master.file.meta.LockingScheme
 
shouldSyncPath(AlluxioURI, long, DescendantType) - Method in class alluxio.master.file.meta.UfsSyncPathCache
Check if sync should happen.
shouldSyncWithTime(long) - Static method in class alluxio.master.file.meta.SyncCheck
Create a SyncCheck object indicating a sync is needed, given the last sync time.
shouldUseDisplayValue() - Method in class alluxio.conf.ConfigurationValueOptions
 
shouldUseRawValue() - Method in class alluxio.conf.ConfigurationValueOptions
 
showAllMembers() - Method in class alluxio.membership.EtcdMembershipManager
 
showAllMembers() - Method in class alluxio.membership.MasterMembershipManager
 
showAllMembers() - Method in interface alluxio.membership.MembershipManager
Pretty printed members and its liveness status.
showAllMembers() - Method in class alluxio.membership.StaticMembershipManager
 
shutdown() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Possibly initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class alluxio.fsmaster.BenchStandaloneGrpcServer
 
shutdown() - Method in class alluxio.grpc.GrpcChannel
Shuts down the channel.
shutdown() - Method in class alluxio.grpc.GrpcServer
Shuts down the server.
shutdown() - Method in class alluxio.master.AlluxioExecutorService
 
shutdown() - Method in class alluxio.metrics.InstrumentedExecutorService
 
shutdown() - Static method in class alluxio.proxy.s3.MultipartUploadCleaner
Shutdown cleaner.
shutdown() - Method in class alluxio.util.executor.ControllableScheduler
 
shutdown() - Method in class alluxio.worker.dora.DoraOpenFileHandleContainer
Wakeup the current thread and ask it to stop.
shutdownAndAwaitTermination(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceUtils
ShutdownAndAwaitTermination with default timeout.
shutdownAndAwaitTermination(ExecutorService, long) - Static method in class alluxio.util.executor.ExecutorServiceUtils
Gracefully shutdown ExecutorService method.
shutdownAndAwaitTermination(ExecutorService, long) - Static method in class alluxio.util.ThreadUtils
From https://docs.oracle.com/javase/7/docs/api/java/util/concurrent/ExecutorService.html The following method shuts down an ExecutorService in two phases, first by calling shutdown to reject incoming tasks, and then calling shutdownNow, if necessary, to cancel any lingering tasks.
shutdownNow() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Possibly attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
shutdownNow() - Method in class alluxio.master.AlluxioExecutorService
 
shutdownNow() - Method in class alluxio.metrics.InstrumentedExecutorService
 
shutdownNow() - Method in class alluxio.util.executor.ControllableScheduler
 
signalLosePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
Notifies this journal that it is no longer primary.
signalNewSnapshot() - Method in class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
Signal to the StateMachineStorage that a new snapshot was taken.
SignatureInfo - Class in alluxio.s3.signature
Signature and related information.
SignatureInfo(SignatureInfo.Version, String, String, String, String, String, String, String, boolean) - Constructor for class alluxio.s3.signature.SignatureInfo
Constructs a new SignatureInfo.
SignatureInfo.Version - Enum in alluxio.s3.signature
Signature version.
SIMPLE_VALUE - Static variable in enum alluxio.grpc.ChannelAuthenticationScheme
SIMPLE = 1;
SimpleAuthenticationProvider - Class in alluxio.security.authentication.plain
An authentication provider implementation that allows arbitrary combination of username and password including empty strings.
SimpleAuthenticationProvider() - Constructor for class alluxio.security.authentication.plain.SimpleAuthenticationProvider
SimpleCuckooTable - Class in alluxio.client.file.cache.cuckoofilter
A simple cuckoo table.
SimpleCuckooTable(BitSet, int, int, int) - Constructor for class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
Create a single cuckoo table on given bit set.
SimpleFuseStreamFactory - Class in alluxio.fuse.file
Factory for FuseFileInStream.
SimpleFuseStreamFactory(FileSystem, AuthPolicy) - Constructor for class alluxio.fuse.file.SimpleFuseStreamFactory
Creates an instance of FuseStreamFactory for creating fuse streams.
SimpleInodeLockList - Class in alluxio.master.file.meta
A simple inode lock list.
SimpleInodeLockList(InodeLockManager, boolean) - Constructor for class alluxio.master.file.meta.SimpleInodeLockList
Creates a new empty lock list.
SimpleJobStatusBlock - Class in alluxio.job.wire
Class for simple job status information.
SimpleJobStatusBlock(long, Status, String, String) - Constructor for class alluxio.job.wire.SimpleJobStatusBlock
Constructor.
SimpleRateLimiter - Class in alluxio.util
A basic implementation of RateLimiter.
SimpleRateLimiter(long, Ticker) - Constructor for class alluxio.util.SimpleRateLimiter
Creates a simple rate limiter for testing purpose.
SimpleService - Interface in alluxio.master.service
Defines a simple start/promote/demote/stop interface for interacting with simple Alluxio master components such as the web server, metrics server, rpc server, etc...
SimpleUserState - Class in alluxio.security.user
UserState implementation for the simple authentication schemes.
SimpleUserState.Factory - Class in alluxio.security.user
Factory class to create the user state.
sInfoDumpOnExitCheck - Static variable in class alluxio.ProcessUtils
 
SINGLE_MASTER_AUTH - Static variable in interface alluxio.uri.Authority
 
singleElementIterator(T) - Static method in class alluxio.util.CommonUtils
Returns an iterator that iterates on a single element.
SingleEntryJournaled - Class in alluxio.master.journal
Journaled component responsible for journaling a single journal entry.
SingleEntryJournaled() - Constructor for class alluxio.master.journal.SingleEntryJournaled
 
SingleMasterAuthority - Class in alluxio.uri
A single master authority implementation.
SingleMasterAuthority(String, int) - Constructor for class alluxio.uri.SingleMasterAuthority
 
SingleMasterConnectDetails(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
SingleMasterInquireClient - Class in alluxio.master
A MasterInquireClient which always returns a fixed master address.
SingleMasterInquireClient(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient
 
SingleMasterInquireClient.SingleMasterConnectDetails - Class in alluxio.master
Connect details for a single master inquire client.
SingleTagValueAggregator - Class in alluxio.metrics.aggregator
An aggregator that aggregates the metrics into multiple values based on a single tag of the metric.
SingleTagValueAggregator(String, String, String) - Constructor for class alluxio.metrics.aggregator.SingleTagValueAggregator
Constructs a new instance of SingleTagValueAggregator.
SingleValueAggregator - Interface in alluxio.metrics
Interface for the aggregator that aggregates into a single value from the metrics of different hosts.
Sink - Interface in alluxio.metrics.sink
Sink consumes the records generated by the metrics source.
SINK_REGEX - Static variable in class alluxio.metrics.MetricsSystem
 
sinkAppend(Supplier<Set<JournalSink>>, Journal.JournalEntry) - Static method in class alluxio.master.journal.JournalUtils
Appends a journal entry to all the supplied journal sinks.
sinkFlush(Supplier<Set<JournalSink>>) - Static method in class alluxio.master.journal.JournalUtils
Appends a flush to all the supplied journal sinks.
SITE_CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
SITE_CONF_DIR - Static variable in class alluxio.conf.PropertyKey
 
SITE_PROPERTIES - Static variable in class alluxio.Constants
 
siteProperty(String) - Static method in class alluxio.conf.Source
Creates a site property source with the specified filename.
size() - Method in class alluxio.client.file.MetadataCache
 
size() - Method in interface alluxio.collections.BitSet
 
size() - Method in class alluxio.collections.BuiltinBitSet
 
size() - Method in class alluxio.collections.ConcurrentHashSet
 
size() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
size() - Method in class alluxio.collections.DelegatingSet
 
size() - Method in interface alluxio.collections.FieldIndex
 
size() - Method in class alluxio.collections.IndexedSet
 
size() - Method in class alluxio.collections.LockPool
 
size() - Method in class alluxio.collections.NonUniqueFieldIndex
 
size() - Method in class alluxio.collections.UniqueFieldIndex
 
size() - Method in class alluxio.collections.UnmodifiableArrayList
 
size() - Method in class alluxio.DefaultStorageTierAssoc
 
size() - Method in class alluxio.master.file.meta.LockedInodePath
 
size() - Method in class alluxio.master.file.meta.TtlBucket
 
size() - Method in interface alluxio.master.metastore.BlockMetaStore
 
size() - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
size() - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
size() - Method in class alluxio.master.transport.Listeners
 
size() - Method in class alluxio.metrics.MaxReservoir
Returns the number of values recorded.
size(CloseableIterator<?>) - Static method in class alluxio.resource.CloseableIterator
Consumes the iterator, closes it, and returns its size.
size() - Method in class alluxio.resource.DynamicResourcePool
 
size() - Method in interface alluxio.resource.Pool
 
size() - Method in class alluxio.resource.ResourcePool
 
size() - Method in interface alluxio.StorageTierAssoc
 
size() - Method in class alluxio.StreamCache
 
size() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
size() - Method in interface alluxio.worker.dora.DoraMetaStore
 
size() - Method in class alluxio.worker.dora.RocksDBDoraMetaStore
Queries the estimated number of the records in this RocksDB.
SizeCommand - Class in alluxio.cli.command.metadatacache
The metadata cache 'size' subcommand.
SizeCommand(FileSystem, AlluxioConfiguration, String) - Constructor for class alluxio.cli.command.metadatacache.SizeCommand
 
SizeEncoder - Class in alluxio.client.file.cache.cuckoofilter
A size encoder that supports encode/decode size information.
SizeEncoder(int, int) - Constructor for class alluxio.client.file.cache.cuckoofilter.SizeEncoder
Creates a new instance of SizeEncoder.
SKEWED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
skip(long) - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
skip(long) - Method in class alluxio.client.file.PositionReadFileInStream
 
skip(long) - Method in class alluxio.client.file.ufs.UfsFileInStream
 
skip(long) - Method in class alluxio.file.SeekableBufferedInputStream
 
skip(long) - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
skip(long) - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
skip(long) - Method in class alluxio.underfs.cephfs.CephInputStream
 
skip(long) - Method in class alluxio.underfs.gcs.GCSInputStream
This method leverages the ability to open a stream from GCS from a given offset.
skip(long) - Method in class alluxio.underfs.gcs.v2.GCSV2InputStream
This method leverages the ability to open a stream from GCS from a given offset.
skip(long) - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
skip(long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
skip(long) - Method in class alluxio.underfs.s3a.S3AInputStream
 
SKIP_IF_EXISTS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileRequest
 
SKIP_IF_EXISTS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
SKIPIFEXISTS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadJobPOptions
 
skippedSync() - Method in class alluxio.master.file.meta.SyncCheck
This method should be called if the sync skipped due to the existence of a recent sync.
sleep(Duration) - Method in interface alluxio.time.Sleeper
Sleeps for the given duration.
sleep(Supplier<Duration>) - Method in interface alluxio.time.Sleeper
Sleeps for given duration but period wake-up by new interval supplier.
sleep(Duration) - Method in class alluxio.time.SteppingThreadSleeper
 
sleep(Supplier<Duration>) - Method in class alluxio.time.SteppingThreadSleeper
 
sleep(Duration) - Method in class alluxio.time.ThreadSleeper
 
Sleeper - Interface in alluxio.time
An interface for a utility which provides a sleep method.
SLEEPING_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
 
SleepingRetry - Class in alluxio.retry
A retry policy that uses thread sleeping for the delay.
SleepingRetry(int) - Constructor for class alluxio.retry.SleepingRetry
 
SleepingTimer - Class in alluxio.heartbeat
This class can be used for executing heartbeats periodically.
SleepingTimer(String, Clock, Supplier<SleepIntervalSupplier>) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
SleepingTimer(String, Logger, Clock, Sleeper, Supplier<SleepIntervalSupplier>) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
SleepIntervalSupplier - Interface in alluxio.heartbeat
A policy to calculate the next interval to sleep.
sleepMs(long) - Static method in class alluxio.util.CommonUtils
Sleeps for the given number of milliseconds.
sleepMs(Logger, long) - Static method in class alluxio.util.CommonUtils
Sleeps for the given number of milliseconds, reporting interruptions using the given logger.
sleepMs(long) - Static method in class alluxio.util.SleepUtils
Sleeps for the given number of milliseconds.
sleepMs(Logger, long) - Static method in class alluxio.util.SleepUtils
Sleeps for the given number of milliseconds, reporting interruptions using the given logger.
SleepUtils - Class in alluxio.util
Sleep utilities shared by all components in Alluxio.
Slf4jSink - Class in alluxio.metrics.sink
A sink which outputs metric values to the metrics logger.
Slf4jSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.Slf4jSink
Creates a new Slf4jSink with a Properties and MetricRegistry.
sliceByteBuffer(ByteBuffer, int, int) - Static method in class alluxio.util.io.BufferUtils
Creates a new ByteBuffer sliced from a given ByteBuffer.
sliceByteBuffer(ByteBuffer, int) - Static method in class alluxio.util.io.BufferUtils
Convenience method for BufferUtils.sliceByteBuffer(ByteBuffer, int, int) where the last parameter is the number of remaining bytes in the new buffer.
SlidingWindowType - Enum in alluxio.client.file.cache.cuckoofilter
This class represents the type of sliding window.
snapshot() - Method in interface alluxio.client.file.cache.CacheUsage
Creates an immutable snapshot of the current cache usage.
snapshot() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
snapshot() - Method in class alluxio.master.meta.PathProperties
 
snapshot(Blackhole, SnapshotBench.Snapshot) - Method in class alluxio.snapshot.SnapshotBench
 
Snapshot() - Constructor for class alluxio.snapshot.SnapshotBench.Snapshot
 
SnapshotBench - Class in alluxio.snapshot
 
SnapshotBench() - Constructor for class alluxio.snapshot.SnapshotBench
 
SnapshotBench.Snapshot - Class in alluxio.snapshot
 
SnapshotData - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SnapshotData
SnapshotData.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SnapshotData
SnapshotDataOrBuilder - Interface in alluxio.grpc
 
SnapshotDirStateMachineStorage - Class in alluxio.master.journal.raft
Simple state machine storage that can handle directories.
SnapshotDirStateMachineStorage() - Constructor for class alluxio.master.journal.raft.SnapshotDirStateMachineStorage
 
SnapshotIdJournaled - Class in alluxio.master.journal.raft
Simple implementation to write and recover the snapshot ID when checkpointing.
SnapshotIdJournaled() - Constructor for class alluxio.master.journal.raft.SnapshotIdJournaled
 
SNAPSHOTINDEX_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
 
SNAPSHOTINDEX_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotMetadata
 
SNAPSHOTINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
SNAPSHOTINFOREQUEST_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryRequest
 
SNAPSHOTINFORESPONSE_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
SnapshotMetadata - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SnapshotMetadata
SnapshotMetadata.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.SnapshotMetadata
SnapshotMetadataOrBuilder - Interface in alluxio.grpc
 
SNAPSHOTREQUEST_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryRequest
 
SNAPSHOTTERM_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotData
 
SNAPSHOTTERM_FIELD_NUMBER - Static variable in class alluxio.grpc.SnapshotMetadata
 
SOCKET_TIMEOUT_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
SOCKET_TIMEOUT_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
SORTED_BY_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
sortedMapToIterator(SortedMap<String, Long>, ReadOption) - Static method in class alluxio.master.metastore.heap.HeapInodeStore
Helper function that returns an iterator over the sorted map using the given read options.
SortingColumn - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.SortingColumn
SortingColumn.Builder - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.SortingColumn
SortingColumn.SortingOrder - Enum in alluxio.grpc.table.layout.hive
Protobuf enum alluxio.grpc.table.layout.SortingColumn.SortingOrder
SortingColumnOrBuilder - Interface in alluxio.grpc.table.layout.hive
 
sortTopologically(Set<T>) - Method in class alluxio.collections.DirectedAcyclicGraph
Sorts a given set of payloads topologically based on the DAG.
Source - Class in alluxio.conf
The source of a configuration property.
Source - Interface in alluxio.metrics.source
Source is where the metrics generated.
Source.Type - Enum in alluxio.conf
Source type.
SOURCE_FIELD_NUMBER - Static variable in class alluxio.grpc.ClientMetrics
 
SOURCE_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigProperty
 
SOURCE_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
 
SOURCE_HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
 
SOURCE_HOST_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
 
SOURCE_HOST_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
SOURCE_PORT_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
 
SOURCE_PORT_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
 
SOURCE_PORT_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
SPACE_TO_RESERVE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
SPACE_TO_RESERVE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
sparsePrint(PrintStream) - Method in class alluxio.job.util.TimeSeries
Print the time series sparsely, i.e.
SPEC_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LayoutSpec
 
SPEC_FIELD_NUMBER - Static variable in class alluxio.grpc.table.PartitionSpec
 
specialCommandEnabled() - Method in class alluxio.fuse.options.FuseOptions
 
SPECIFIED_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.command.ReportCommand
 
SPECIFIED_VALUE - Static variable in enum alluxio.grpc.WorkerRange
SPECIFIED = 4;
specifiedMaster(InetSocketAddress) - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
Creates a MasterSelectionPolicy that selects a specified master to connect.
SpeedStat() - Constructor for class alluxio.stress.worker.IOTaskSummary.SpeedStat
An empty constructor.
spliterator() - Method in class alluxio.collections.DelegatingSet
 
SRC_FIELD_NUMBER - Static variable in class alluxio.grpc.Route
 
SRC_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
SRC_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
SRCPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPOptions
 
SshCommand - Class in alluxio.shell
Object representation of a remote shell command by SSH.
SshCommand(String, String[]) - Constructor for class alluxio.shell.SshCommand
Creates a SshCommand instance from the remote hostname and command.
sshExecCommandWithOutput(String, String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command remotely via ssh.
SshValidationTask - Class in alluxio.cli
Task for validating SSH reachability.
SshValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.SshValidationTask
Creates a new instance of SshValidationTask for validating ssh accessibility.
sslContext(SslContext) - Method in class alluxio.grpc.GrpcServerBuilder
Sets TLS context.
SslContextProvider - Interface in alluxio.util.network.tls
Interface for providing SslContext instances for TLS support.
SslContextProvider.Factory - Class in alluxio.util.network.tls
Factory for creating context provider implementations.
StackFS - Class in alluxio.fuse
Stack FS implements the FUSE callbacks defined by jni-fuse without interactions with Alluxio clients/servers.
StackFS(Path, Path) - Constructor for class alluxio.fuse.StackFS
 
StackMain - Class in alluxio.fuse
Main entry for StackFS.
StackMain() - Constructor for class alluxio.fuse.StackMain
 
StacksServlet - Class in alluxio.web
Stacks servlet to display the stacks of this process.
StacksServlet() - Constructor for class alluxio.web.StacksServlet
 
STANDALONE_FUSE_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
STANDALONE_FUSE_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
StandardURI - Class in alluxio.uri
A standard URI implementation.
StandardURI(String, Authority, String, String) - Constructor for class alluxio.uri.StandardURI
 
StandardURI(URI, String) - Constructor for class alluxio.uri.StandardURI
Constructs a new URI from a base URI, but with a new path component.
STANDBY_MASTER_GRPC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
STANDBY_MASTER_GRPC_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
STANDBY_MASTER_METRICS_SINK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
STANDBY_MASTER_METRICS_SINK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
STANDBY_MASTER_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
STANDBY_MASTER_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
STANDBY_VALUE - Static variable in enum alluxio.grpc.NodeState
STANDBY = 0;
start(AlluxioConfiguration) - Method in class alluxio.fuse.AlluxioFuse
Startup the FUSE process.
start() - Method in class alluxio.grpc.GrpcServer
Start serving.
start() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Starts both master and a worker using the configurations in test conf respectively.
start(Boolean) - Method in class alluxio.master.AbstractMaster
 
start() - Method in class alluxio.master.AlluxioMasterProcess
 
start() - Method in class alluxio.master.AlluxioSimpleMasterProcess
 
start(InetSocketAddress) - Method in class alluxio.master.AlwaysStandbyPrimarySelector
 
start() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
start(Boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
start(Boolean) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
start(Boolean) - Method in class alluxio.master.job.JobMaster
 
start() - Method in class alluxio.master.journal.AbstractJournalSystem
 
start() - Method in interface alluxio.master.journal.JournalSystem
Starts the journal system.
start() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
start(InetSocketAddress) - Method in class alluxio.master.journal.raft.RaftPrimarySelector
 
start() - Method in class alluxio.master.journal.ufs.UfsJournal
Starts the journal in standby mode.
start(InetSocketAddress) - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
Starts the leader selection.
start(InetSocketAddress) - Method in class alluxio.master.journal.ufs.UfsJournalSingleMasterPrimarySelector
 
start() - Method in class alluxio.master.LocalAlluxioJobCluster
Starts both master and a worker using the configurations in test conf respectively.
start() - Method in class alluxio.master.LocalAlluxioMaster
Starts the master.
start() - Method in class alluxio.master.meta.DailyMetadataBackup
start(Boolean) - Method in class alluxio.master.meta.DefaultMetaMaster
 
start(Boolean) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
start(Boolean) - Method in class alluxio.master.NoopMaster
 
start(InetSocketAddress) - Method in interface alluxio.master.PrimarySelector
Starts the primary selector.
start() - Method in class alluxio.master.scheduler.Scheduler
Start scheduler.
start() - Method in class alluxio.master.service.jvmmonitor.JvmMonitorService
 
start() - Method in class alluxio.master.service.NoopService
 
start() - Method in class alluxio.master.service.rpc.RpcServerService
 
start() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
start() - Method in interface alluxio.master.service.SimpleService
Starts the service.
start() - Method in class alluxio.metrics.sink.ConsoleSink
 
start() - Method in class alluxio.metrics.sink.CsvSink
 
start() - Method in class alluxio.metrics.sink.GraphiteSink
 
start() - Method in class alluxio.metrics.sink.JmxSink
 
start() - Method in class alluxio.metrics.sink.MetricsServlet
 
start() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
 
start() - Method in interface alluxio.metrics.sink.Sink
Starts the reporter polling.
start() - Method in class alluxio.metrics.sink.Slf4jSink
 
start() - Method in class alluxio.multi.process.BaseMaster
Launches the master process.
start() - Method in class alluxio.multi.process.ExternalProcess
Starts the process.
start() - Method in class alluxio.multi.process.MultiProcessCluster
Starts the cluster, launching all server processes.
start() - Method in class alluxio.multi.process.Worker
Launches the worker process.
start() - Method in interface alluxio.Process
Starts the Alluxio process.
start() - Method in class alluxio.proxy.AlluxioProxyProcess
 
start(U) - Method in class alluxio.Registry
Starts all Servers in dependency order.
start(T) - Method in interface alluxio.Server
Starts the Alluxio server.
start() - Method in class alluxio.underfs.UfsIOManager
Start schedule thread.
start() - Method in class alluxio.util.JvmPauseMonitor
Starts jvm monitor thread.
start() - Method in class alluxio.web.WebServer
Starts the web server.
start(WorkerNetAddress) - Method in class alluxio.worker.AbstractWorker
 
start() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
start() - Method in class alluxio.worker.AlluxioWorkerProcess
 
start(WorkerNetAddress) - Method in class alluxio.worker.dora.PagedDoraWorker
 
start() - Method in class alluxio.worker.http.HttpServer
Starts the HTTP server.
start(WorkerNetAddress) - Method in class alluxio.worker.JobWorker
 
START_MS_FLAG - Static variable in class alluxio.stress.BaseParameters
 
START_TIME_MS_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
START_TIME_MS = 4;
START_TIME_MS_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
START_TIME_MS = 6;
STARTAFTER_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
 
startAuthenticatedChannel(long) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Starts authentication with the server and wait until completion.
startCommon(AlluxioConfiguration, FuseOptions, FileSystemContext) - Method in class alluxio.fuse.AlluxioFuse
Start common functionalities for a fuse client.
startGrpcServer(Function<Master, Map<ServiceType, GrpcService>>) - Method in class alluxio.master.service.rpc.RpcServerService
 
startInternal() - Method in class alluxio.master.journal.AbstractJournalSystem
Starts the journal system.
startInternal() - Method in class alluxio.master.journal.raft.RaftJournalSystem
Throws AlluxioRuntimeException when it cannot start a RaftCluster and therefore cannot join the quorum.
startInternal() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
startJvmMonitorProcess() - Static method in class alluxio.fuse.AlluxioFuse
Starts jvm monitor process, to monitor jvm.
startMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
Starts the specified master.
startMasterComponents(boolean) - Method in class alluxio.master.AlluxioMasterProcess
Starts all masters, including block master, FileSystem master, and additional masters.
startMasterComponents(boolean) - Method in class alluxio.master.AlluxioSimpleMasterProcess
 
startMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Configures and starts the master(s).
startMasters() - Method in class alluxio.master.LocalAlluxioCluster
 
startMasters() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
startMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
startMasters() - Method in class alluxio.multi.process.MultiProcessCluster
Starts all masters.
startMetricsSystem() - Method in class alluxio.master.service.metrics.MetricsService
 
startNewMasters(int, boolean) - Method in class alluxio.multi.process.MultiProcessCluster
Start a number of new master nodes.
startProxy() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Configures and starts the proxy.
startProxy() - Method in class alluxio.master.LocalAlluxioCluster
 
startRejectingServer() - Method in class alluxio.master.service.rpc.RpcServerService
 
startServer(int) - Method in class alluxio.fsmaster.BenchStandaloneGrpcServer
 
startSinks(String) - Static method in class alluxio.metrics.MetricsSystem
Starts sinks specified in the configuration.
startSinksFromConfig(MetricsConfig) - Static method in class alluxio.metrics.MetricsSystem
Starts sinks from a given metrics configuration.
startsWithIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array contains an increasing sequence of bytes of the given length, starting from the given value.
STARTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterStatus
 
STARTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyHeartbeatPOptions
 
STARTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyStatus
 
STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobMasterPOptions
 
STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPOptions
 
STARTTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
startUpload() - Method in interface alluxio.underfs.MultipartUploader
Initialize a multipart upload.
startWebServer() - Method in class alluxio.master.service.web.WebServerService
 
startWorker(int) - Method in class alluxio.multi.process.MultiProcessCluster
Starts the specified worker.
startWorkers() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Configures and starts the worker(s).
startWorkers() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
startWorkers() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
StatCommand - Class in alluxio.cli.fs.command
Displays the path's info.
StatCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.StatCommand
 
state() - Method in interface alluxio.client.file.cache.CacheManager
 
state() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
state() - Method in class alluxio.client.file.cache.LocalCacheManager
 
state() - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
State() - Constructor for class alluxio.master.meta.DefaultMetaMaster.State
 
State() - Constructor for class alluxio.master.meta.PathProperties.State
 
STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterStatus
 
STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterVersion
 
STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyStatus
 
STATE_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
STATE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
STATE_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
STATE = 7;
stateChanged(CuratorFramework, ConnectionState) - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
 
StateChangeJournalContext - Class in alluxio.master.journal
Context for correctly managing the state change lock for a wrapped journal context.
StateChangeJournalContext(JournalContext, LockResource) - Constructor for class alluxio.master.journal.StateChangeJournalContext
StateListener - Interface in alluxio.membership
Interface for getting callback on watch event from etcd.
StateLockManager - Class in alluxio.master
Provides graceful and interruptable locking protocol for taking the state lock.
StateLockManager() - Constructor for class alluxio.master.StateLockManager
Creates a new state-lock manager.
StateLockOptions - Class in alluxio.master
Used to define state-lock options for taking it exclusively.
StateLockOptions(GraceMode, long, long, long) - Constructor for class alluxio.master.StateLockOptions
Creates an option class that is consulted while taking a state-lock exclusively from StateLockManager.
statfs(String, Statvfs) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
Gets the filesystem statistics.
statfs(String, Statvfs) - Method in class alluxio.fuse.StackFS
 
statfs(String, Statvfs) - Method in interface alluxio.jnifuse.FuseFileSystem
 
statfsCallback(String, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
StaticMembershipManager - Class in alluxio.membership
MembershipManager configured by a static file.
StaticWorkerMeta - Class in alluxio.master.block.meta
An object representation of the worker metadata.
StaticWorkerMeta(long, WorkerNetAddress) - Constructor for class alluxio.master.block.meta.StaticWorkerMeta
Constructor.
STATISTICS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsList
 
STATISTICS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Layout
 
Status - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.job.Status
Status - Enum in alluxio.job.wire
The status of a task.
Status - Class in alluxio.proto.status
 
Status.PStatus - Enum in alluxio.proto.status
exception status for a response.
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigCheckReport
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyResponse
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetPolicyStatusPResponse
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgress
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.ListAllPOptions
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileResponse
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadResponse
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveResponse
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.StatusSummary
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncDatabasePResponse
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateConfigurationPResponse
 
STATUS_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.Response
 
StatusSummary - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.StatusSummary
StatusSummary - Class in alluxio.job.wire
Status summary.
StatusSummary(Status, long) - Constructor for class alluxio.job.wire.StatusSummary
Constructs a new instance of StatusSummary from a Status and number of jobs with that status.
StatusSummary(StatusSummary) - Constructor for class alluxio.job.wire.StatusSummary
Constructs a new instance of StatusSummary from a proto object.
StatusSummary.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.StatusSummary
StatusSummaryOrBuilder - Interface in alluxio.grpc
 
Statvfs - Class in alluxio.jnifuse.struct
 
Statvfs(Runtime, ByteBuffer) - Constructor for class alluxio.jnifuse.struct.Statvfs
 
SteppingThreadSleeper - Class in alluxio.time
A progressive sleeper that wakes up multiple times during sleep to check if the requested sleep duration has changed, and adjust its sleep duration accordingly.
SteppingThreadSleeper(Sleeper, Clock) - Constructor for class alluxio.time.SteppingThreadSleeper
Creates a new instance of SteppingThreadSleeper.
stop(Status, String, String) - Method in class alluxio.job.workflow.WorkflowExecution
stops future execution.
stop() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops both the alluxio and underfs service threads.
stop() - Method in class alluxio.master.AbstractMaster
 
stop() - Method in class alluxio.master.AlluxioMasterProcess
 
stop() - Method in class alluxio.master.AlluxioSimpleMasterProcess
Stops the Alluxio master server.
stop() - Method in class alluxio.master.AlwaysStandbyPrimarySelector
 
stop() - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
stop() - Method in class alluxio.master.block.DefaultBlockMaster
 
stop() - Method in class alluxio.master.file.DefaultFileSystemMaster
 
stop() - Method in class alluxio.master.job.JobMaster
 
stop() - Method in class alluxio.master.journal.AbstractJournalSystem
 
stop() - Method in interface alluxio.master.journal.JournalSystem
Stops the journal system.
stop() - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
stop() - Method in class alluxio.master.journal.raft.RaftPrimarySelector
 
stop() - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
 
stop() - Method in class alluxio.master.journal.ufs.UfsJournalSingleMasterPrimarySelector
 
stop() - Method in class alluxio.master.LocalAlluxioCluster
 
stop() - Method in class alluxio.master.LocalAlluxioJobCluster
Stops the alluxio job service threads.
stop() - Method in class alluxio.master.LocalAlluxioMaster
Stops the master processes and cleans up client connections.
stop() - Method in class alluxio.master.meta.DailyMetadataBackup
stop() - Method in class alluxio.master.meta.DefaultMetaMaster
 
stop() - Method in class alluxio.master.NoopMaster
 
stop() - Method in interface alluxio.master.PrimarySelector
Stops the primary selector.
stop() - Method in class alluxio.master.scheduler.Scheduler
Stop scheduler.
stop() - Method in class alluxio.master.service.jvmmonitor.JvmMonitorService
 
stop() - Method in class alluxio.master.service.NoopService
 
stop() - Method in class alluxio.master.service.rpc.RpcServerService
 
stop() - Method in class alluxio.master.service.rpc.RpcServerStandbyGrpcService
 
stop() - Method in interface alluxio.master.service.SimpleService
Stops the service altogether and cleans up any state left.
stop() - Method in class alluxio.metrics.sink.ConsoleSink
 
stop() - Method in class alluxio.metrics.sink.CsvSink
 
stop() - Method in class alluxio.metrics.sink.GraphiteSink
 
stop() - Method in class alluxio.metrics.sink.JmxSink
 
stop() - Method in class alluxio.metrics.sink.MetricsServlet
 
stop() - Method in class alluxio.metrics.sink.PrometheusMetricsServlet
 
stop() - Method in interface alluxio.metrics.sink.Sink
Stops the reporter.
stop() - Method in class alluxio.metrics.sink.Slf4jSink
 
stop() - Method in class alluxio.multi.process.ExternalProcess
Stops the process.
stop() - Method in interface alluxio.Process
Stops the Alluxio process, blocking until the action is completed.
stop() - Method in class alluxio.proxy.AlluxioProxyProcess
 
stop() - Method in class alluxio.Registry
Stops all Servers in reverse dependency order.
stop() - Method in interface alluxio.Server
Stops the Alluxio server.
stop() - Method in class alluxio.util.JvmPauseMonitor
Stops jvm monitor.
stop() - Method in class alluxio.web.MasterWebServer
 
stop() - Method in class alluxio.web.ProxyWebServer
 
stop() - Method in class alluxio.web.WebServer
Shuts down the web server.
stop() - Method in class alluxio.web.WorkerWebServer
 
stop() - Method in class alluxio.worker.AbstractWorker
 
stop() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
stop() - Method in class alluxio.worker.AlluxioWorkerProcess
 
stop() - Method in class alluxio.worker.dora.PagedDoraWorker
 
stop() - Method in class alluxio.worker.JobWorker
 
stopAndJoin() - Method in class alluxio.network.RejectingServer
Stops the server and joins the server thread.
stopAndRemoveMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
Removes master i from the cluster.
stopCommon() - Method in class alluxio.fuse.AlluxioFuse
 
stopFS() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the alluxio filesystem's service thread only.
stopFS() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
stopFS() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
stopGrpcServer() - Method in class alluxio.master.service.rpc.RpcServerService
 
stopHeartBeat(WorkerInfo) - Method in class alluxio.membership.EtcdMembershipManager
 
stopHeartBeat(WorkerInfo) - Method in class alluxio.membership.MasterMembershipManager
 
stopHeartBeat(WorkerInfo) - Method in interface alluxio.membership.MembershipManager
Stop heartbeating for liveness for current worker.
stopHeartBeat(WorkerInfo) - Method in class alluxio.membership.StaticMembershipManager
 
stopInternal() - Method in class alluxio.master.journal.AbstractJournalSystem
Stops the journal system.
stopInternal() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
stopInternal() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
stopJob(JobDescription) - Method in class alluxio.client.file.DelegatingFileSystem
 
stopJob(JobDescription) - Method in interface alluxio.client.file.FileSystem
Stop a job in scheduler.
stopJob(JobDescription) - Method in interface alluxio.client.file.FileSystemMasterClient
Stop a job.
stopJob(JobDescription) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
stopJob(JobDescription) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
stopJob(StopJobPRequest, StreamObserver<StopJobPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
 
stopJob(StopJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
 
stopJob(StopJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
 
stopJob(StopJobPRequest, StreamObserver<StopJobPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
 
stopJob(StopJobPRequest, StreamObserver<StopJobPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
stopJob(JobDescription) - Method in class alluxio.master.scheduler.Scheduler
Stop a job.
StopJobPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopJobPRequest
StopJobPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopJobPRequest
StopJobPRequestOrBuilder - Interface in alluxio.grpc
 
StopJobPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopJobPResponse
StopJobPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.StopJobPResponse
StopJobPResponseOrBuilder - Interface in alluxio.grpc
 
stopLeader() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the leader master.
stopLeader() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the leader master.
stopMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
 
stopMasterComponents() - Method in class alluxio.master.AlluxioMasterProcess
Stops all masters, including block master, fileSystem master and additional masters.
stopMasterComponents() - Method in class alluxio.master.AlluxioSimpleMasterProcess
 
stopMasters() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the masters.
stopMasters() - Method in class alluxio.master.LocalAlluxioCluster
 
stopMasters() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
 
stopMasters() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
 
stopMasters() - Method in class alluxio.multi.process.MultiProcessCluster
Stops all masters.
stopMetricsSystem() - Method in class alluxio.master.service.metrics.MetricsService
 
STOPPED_VALUE - Static variable in enum alluxio.proto.journal.Job.PJobState
STOPPED = 2;
stopProcessOnShutdown(Process) - Static method in class alluxio.ProcessUtils
Adds a shutdown hook that will be invoked when a signal is sent to this process.
stopProxy() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the proxy.
stopRejectingServer() - Method in class alluxio.master.service.rpc.RpcServerService
 
stopRpcExecutor() - Method in class alluxio.master.service.rpc.RpcServerService
 
stopSinks() - Static method in class alluxio.metrics.MetricsSystem
Stops all the sinks.
stopStandby() - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the first standby master.
stopStandby() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Iterates over the masters in the order of master creation, stops the first standby master.
stopUpdate() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
Stop to switch bloom filters and update working set size.
stopUpdate() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
stopUpdate() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
stopUpdate() - Method in interface alluxio.client.file.cache.ShadowCacheManager
Stop the background aging task.
stopWebServer() - Method in class alluxio.master.service.web.WebServerService
 
stopWorker(int) - Method in class alluxio.multi.process.MultiProcessCluster
 
stopWorkers() - Method in class alluxio.master.AbstractLocalAlluxioCluster
Stops the workers.
stopZk() - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Stops the cluster's Zookeeper service.
stopZk() - Method in class alluxio.multi.process.MultiProcessCluster
Stops the Zookeeper cluster.
Storage - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.Storage
Storage.Builder - Class in alluxio.grpc.table.layout.hive
Protobuf type alluxio.grpc.table.layout.Storage
STORAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.StorageList
 
STORAGE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
STORAGE_FORMAT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
StorageCommand - Class in alluxio.cli.fsadmin.doctor
Prints server-side storage errors and warnings.
StorageCommand(BlockMasterClient, PrintStream) - Constructor for class alluxio.cli.fsadmin.doctor.StorageCommand
Creates a new instance of StorageCommand.
StorageDir - Interface in alluxio.worker.block.meta
Represents a directory in a storage tier.
StorageFormat - Class in alluxio.grpc.table.layout.hive
TODO(binfan): remove this proto file.
StorageFormat.Builder - Class in alluxio.grpc.table.layout.hive
TODO(binfan): remove this proto file.
StorageFormatOrBuilder - Interface in alluxio.grpc.table.layout.hive
 
StorageList - Class in alluxio.grpc
A list of lost storage paths inside a worker
StorageList.Builder - Class in alluxio.grpc
A list of lost storage paths inside a worker
StorageListOrBuilder - Interface in alluxio.grpc
 
StorageOrBuilder - Interface in alluxio.grpc.table.layout.hive
 
StorageSpaceValidationTask - Class in alluxio.cli
Task for validating whether worker tiered storage has enough space.
StorageSpaceValidationTask(AlluxioConfiguration) - Constructor for class alluxio.cli.StorageSpaceValidationTask
Creates a new instance of StorageSpaceValidationTask for validating tiered storage space.
StorageTier - Interface in alluxio.worker.block.meta
Represents a tier of storage, for example memory or SSD.
StorageTierAssoc - Interface in alluxio
A two-way mapping between storage tier aliases and ordinal numbers from configuration.
StorageTierInfo - Class in alluxio.util.webui
Class to make referencing tiered storage information more intuitive.
StorageTierInfo(String, long, long) - Constructor for class alluxio.util.webui.StorageTierInfo
Instantiates a new Storage tier info.
STORAGETIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
stream() - Method in class alluxio.collections.DelegatingSet
 
stream(T) - Method in class alluxio.grpc.DataMessageMarshaller
 
STREAM_CACHE_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
 
StreamCache - Class in alluxio
Cache for storing file input and output streams.
StreamCache(long) - Constructor for class alluxio.StreamCache
Creates a new instance of StreamCache.
streamingRPCAndLog(Logger, RpcUtils.StreamingRpcCallable<T>, String, boolean, boolean, StreamObserver<T>, String, Object...) - Static method in class alluxio.RpcUtils
Handles a streaming RPC callable with logging.
StreamSerializationClientInterceptor - Class in alluxio.client.block.stream
Serialization interceptor for client.
StreamSerializationClientInterceptor() - Constructor for class alluxio.client.block.stream.StreamSerializationClientInterceptor
 
StreamsRestServiceHandler - Class in alluxio.proxy
This class is a REST handler for stream resources.
StreamsRestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.StreamsRestServiceHandler
Constructs a new StreamsRestServiceHandler.
streamToJournalCheckpoint(JournalOutputStream) - Method in interface alluxio.master.journalv0.JournalCheckpointStreamable
Writes to the journal, in a streaming fashion, via the JournalOutputStream.
StreamUtils - Class in alluxio.util
Convenience methods for working with streams.
StressBenchConfig - Class in alluxio.stress.job
Config for the stress test.
StressBenchConfig(String, List<String>, long, int) - Constructor for class alluxio.stress.job.StressBenchConfig
 
StressBenchDefinition - Class in alluxio.job.plan.stress
The definition for the stress bench job, which runs distributed benchmarks.
StressBenchDefinition() - Constructor for class alluxio.job.plan.stress.StressBenchDefinition
Constructs a new instance.
StressClientIOBench - Class in alluxio.stress.cli.client
Client IO stress test.
StressClientIOBench() - Constructor for class alluxio.stress.cli.client.StressClientIOBench
Creates instance.
StressConstants - Class in alluxio.stress
Constants for stress tests.
StressConstants() - Constructor for class alluxio.stress.StressConstants
 
StressWorkerBench - Class in alluxio.stress.cli.worker
Single node stress test.
StressWorkerBench() - Constructor for class alluxio.stress.cli.worker.StressWorkerBench
Creates instance.
STRING_ENTRY_FIELD - Static variable in class alluxio.security.authorization.AccessControlList
 
STRING_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
STRING_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Value
 
stringBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
StringColumnStatsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.StringColumnStatsData
StringColumnStatsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.StringColumnStatsData
StringColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
 
stringToAddress(String) - Static method in class alluxio.cli.fsadmin.journal.QuorumCommand
 
StringToSignProducer - Class in alluxio.s3.signature
Stateless utility to create stringToSign, the base of the signature.
STRINGVALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.MetricValue
 
stripInstanceAndHost(String) - Static method in class alluxio.metrics.MetricsSystem
Removes the instance and host from the given metric name, returning the result.
stripLeadingAndTrailingQuotes(String) - Static method in class alluxio.util.CommonUtils
Strips the leading and trailing quotes from the given string.
stripPrefixIfPresent(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Strips the bucket prefix or the preceding path separator from the path if it is present.
stripPrefixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
Strips the prefix from the key if it is present.
stripSuffixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
Strips the suffix if it exists.
StsOssClientProvider - Class in alluxio.underfs.oss
STS client provider for Aliyun OSS.
StsOssClientProvider(UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.oss.StsOssClientProvider
Constructs a new instance of StsOssClientProvider.
SUBJECT_FIELD_NUMBER - Static variable in class alluxio.grpc.PAclEntry
 
SUBJECT_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AclEntry
 
subList(int, int) - Method in class alluxio.collections.UnmodifiableArrayList
 
SUBMISSIONTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.CmdSummary
 
submit(CmdConfig) - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
submit(CmdConfig) - Method in interface alluxio.client.job.JobMasterClient
Submit a Cmd Job based on the given configuration.
submit(CmdConfig) - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
submit(ForkJoinTask<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Submits a ForkJoinTask for execution.
submit(Callable<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
submit(Runnable, T) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
submit(Runnable) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in interface alluxio.grpc.JobMasterClientServiceGrpc.AsyncService
Submit a CMD job, return a jobControlId.
submit(SubmitRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceBlockingStub
Submit a CMD job, return a jobControlId.
submit(SubmitRequest) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceFutureStub
Submit a CMD job, return a jobControlId.
submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceStub
Submit a CMD job, return a jobControlId.
submit(Callable<T>) - Method in class alluxio.master.AlluxioExecutorService
 
submit(Runnable, T) - Method in class alluxio.master.AlluxioExecutorService
 
submit(Runnable) - Method in class alluxio.master.AlluxioExecutorService
 
submit(FileInfo) - Method in class alluxio.master.file.ListStatusPartialResultStream
 
submit(FileInfo) - Method in class alluxio.master.file.ListStatusResultStream
 
submit(T) - Method in interface alluxio.master.file.ResultStream
Submits a new item to stream.
submit(CmdConfig) - Method in class alluxio.master.job.JobMaster
Submit a job with the given configuration.
submit(SubmitRequest, StreamObserver<SubmitResponse>) - Method in class alluxio.master.job.JobMasterClientServiceHandler
 
submit(Runnable) - Method in class alluxio.metrics.InstrumentedExecutorService
 
submit(Runnable, T) - Method in class alluxio.metrics.InstrumentedExecutorService
 
submit(Callable<T>) - Method in class alluxio.metrics.InstrumentedExecutorService
 
submit(Callable<T>) - Method in class alluxio.util.executor.ControllableScheduler
 
submit(Runnable) - Method in class alluxio.util.executor.ControllableScheduler
 
submit(Runnable, T) - Method in class alluxio.util.executor.ControllableScheduler
 
submitCancelTaskCommand(long, long, long) - Method in class alluxio.master.job.command.CommandManager
Submits a cancel-task command to a specified worker.
submitJob(JobRequest) - Method in class alluxio.client.file.DelegatingFileSystem
 
submitJob(JobRequest) - Method in interface alluxio.client.file.FileSystem
Submit a job to scheduler.
submitJob(JobRequest) - Method in interface alluxio.client.file.FileSystemMasterClient
Submit a job to scheduler.
submitJob(JobRequest) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
submitJob(JobRequest) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
submitJob(SubmitJobPRequest, StreamObserver<SubmitJobPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Load a directory into Alluxio.
submitJob(SubmitJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Load a directory into Alluxio.
submitJob(SubmitJobPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Load a directory into Alluxio.
submitJob(SubmitJobPRequest, StreamObserver<SubmitJobPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Load a directory into Alluxio.
submitJob(SubmitJobPRequest, StreamObserver<SubmitJobPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
submitJob(Job<?>) - Method in class alluxio.master.scheduler.Scheduler
Submit a job.
SubmitJobPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SubmitJobPRequest
SubmitJobPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SubmitJobPRequest
SubmitJobPRequestOrBuilder - Interface in alluxio.grpc
 
SubmitJobPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SubmitJobPResponse
SubmitJobPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.SubmitJobPResponse
SubmitJobPResponseOrBuilder - Interface in alluxio.grpc
 
submitNewRequest(ReqT) - Method in class alluxio.worker.netty.NettyReadHandlerStateMachine
Submits a new read request for processing in the state machine.
SubmitOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SubmitOptions
SubmitOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SubmitOptions
SubmitOptionsOrBuilder - Interface in alluxio.grpc
 
SubmitRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SubmitRequest
SubmitRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SubmitRequest
SubmitRequestOrBuilder - Interface in alluxio.grpc
 
SubmitResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SubmitResponse
SubmitResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.job.SubmitResponse
SubmitResponseOrBuilder - Interface in alluxio.grpc
 
submitRunTaskCommand(long, long, JobConfig, Object, long) - Method in class alluxio.master.job.command.CommandManager
Submits a run-task command to a specified worker.
submitSetTaskPoolSizeCommand(long, int) - Method in class alluxio.master.job.command.CommandManager
Submits a set thread pool size command to specific worker.
subProperties(Properties, String) - Static method in class alluxio.metrics.MetricsConfig
Uses regex to parse every original property key to a prefix and a suffix.
subtractPaths(String, String) - Static method in class alluxio.util.io.PathUtils
Removes the prefix from the path, yielding a relative path from the second path to the first.
SUCCEEDED_VALUE - Static variable in enum alluxio.proto.journal.Job.PJobState
SUCCEEDED = 3;
SUCCESS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePResponse
 
SUCCESS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DetachDatabasePResponse
 
SUCCESS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncDatabasePResponse
 
SUCCESS_VALUE - Static variable in enum alluxio.grpc.SaslMessageType
SUCCESS = 1;
SUCCESS_VALUE - Static variable in enum alluxio.grpc.TaskStatus
SUCCESS = 0;
summarizeCollection(Object) - Static method in class alluxio.util.CommonUtils
 
Summary() - Constructor for class alluxio.job.util.TimeSeries.Summary
Creates a TimeSeries.Summary instance.
Summary - Interface in alluxio.stress
The aggregated summary of multiple task results.
SUMMARY_FIELD_NUMBER - Static variable in class alluxio.grpc.GetJobServiceSummaryPResponse
 
SummaryCommand - Class in alluxio.cli.fsadmin.report
Prints Alluxio cluster summarized information.
SummaryCommand(MetaMasterClient, BlockMasterClient, String, PrintStream) - Constructor for class alluxio.cli.fsadmin.report.SummaryCommand
Creates a new instance of SummaryCommand.
SummaryOutput - Class in alluxio.cli.fsadmin.report
An output class, describing the summary.
SummaryOutput(MasterInfo, BlockMasterInfo) - Constructor for class alluxio.cli.fsadmin.report.SummaryOutput
Creates a new instance of SummaryOutput.
SUMMARYPERSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobServiceSummary
 
SummaryStatistics - Class in alluxio.stress.common
Statistics class.
SummaryStatistics() - Constructor for class alluxio.stress.common.SummaryStatistics
Creates an instance.
SummaryStatistics(long, float[], float[], float[]) - Constructor for class alluxio.stress.common.SummaryStatistics
Creates an instance.
supplyAsync(Supplier<U>) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the ForkJoinPool.commonPool() with the value obtained by calling the given Supplier.
supplyAsync(Supplier<U>, Executor) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the given executor with the value obtained by calling the given Supplier.
SupportedHdfsAclProvider - Class in alluxio.underfs.hdfs.acl
Provides the HDFS ACLs.
SupportedHdfsAclProvider() - Constructor for class alluxio.underfs.hdfs.acl.SupportedHdfsAclProvider
 
supportsBatchWrite() - Method in interface alluxio.master.metastore.InodeStore
 
supportsBatchWrite() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
supportsFlush() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
supportsFlush() - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystem
 
supportsFlush() - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystem
 
supportsFlush() - Method in class alluxio.underfs.local.LocalUnderFileSystem
 
supportsFlush() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
supportsFlush() - Method in interface alluxio.underfs.UnderFileSystem
Whether this type of UFS supports flush.
supportsFlush() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
supportsPath(String, S) - Method in interface alluxio.extensions.ExtensionFactory
Gets whether this factory supports the given path and thus whether calling the #create(String, S) can succeed for this path.
supportsPath(String) - Method in class alluxio.underfs.abfs.AbfsUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.adl.AdlUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.cephfs.CephFSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
 
supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cephfshadoop.CephfsHadoopUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.cos.COSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
 
supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.cosn.CosNUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.gcs.GCSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
 
supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.hdfs.HdfsUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.local.LocalUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.obs.OBSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.oss.OSSUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
 
supportsPath(String, UnderFileSystemConfiguration) - Method in class alluxio.underfs.ozone.OzoneUnderFileSystemFactory
 
supportsPath(String) - Method in class alluxio.underfs.s3a.S3AUnderFileSystemFactory
 
supportsPath(String) - Method in interface alluxio.underfs.UnderFileSystemFactory
Gets whether this factory supports the given path and thus whether calling the UnderFileSystemFactory.create(String, UnderFileSystemConfiguration) can succeed for this path.
supportsPath(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
Gets whether this factory supports the given path and thus whether calling the UnderFileSystemFactory.create(String, UnderFileSystemConfiguration) can succeed for this path.
supportsPath(String) - Method in class alluxio.underfs.wasb.WasbUnderFileSystemFactory
 
supportsVersion(Version) - Method in class alluxio.master.backcompat.ops.SetAcl
 
supportsVersion(Version) - Method in interface alluxio.master.backcompat.TestOp
 
SuppressFBWarnings - Annotation Type in alluxio.annotation
Suppresses warnings by findbugs-maven-plugin.
suspend(Runnable) - Method in interface alluxio.master.journal.JournalSystem
Suspends applying for all journals.
suspend(Runnable) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
suspend() - Method in class alluxio.master.journal.raft.BufferedJournalApplier
Suspend the applier.
suspend(Runnable) - Method in class alluxio.master.journal.raft.JournalStateMachine
Suspends applying to masters.
suspend(Runnable) - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
suspend() - Method in class alluxio.master.journal.ufs.UfsJournal
Suspends applying this journal until resumed.
suspend(Runnable) - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
SWIFT_AUTH_KEYSTONE - Static variable in class alluxio.Constants
 
SWIFT_AUTH_KEYSTONE_V3 - Static variable in class alluxio.Constants
 
SWIFT_AUTH_SWIFTAUTH - Static variable in class alluxio.Constants
 
symlink(String, String) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
symlink(String, String) - Method in interface alluxio.jnifuse.FuseFileSystem
 
symlinkCallback(String, String) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
sync() - Method in class alluxio.master.file.InodeSyncStream
Sync the metadata according the root path the stream was created with.
SYNC_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePResponse
 
SyncCheck - Class in alluxio.master.file.meta
Returned by UfsSyncPathCache.shouldSyncPath(alluxio.AlluxioURI, long, alluxio.file.options.DescendantType) indicating whether a sync is needed as well as the time of the last sync if one is not needed.
SyncCheck.SyncResult - Class in alluxio.master.file.meta
Information about the result of a synchronization, created by calling SyncCheck.syncSuccess() or SyncCheck.skippedSync(), or using SyncCheck.SyncResult.INVALID_RESULT if the sync failed due to an external reason.
syncDatabase(String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
syncDatabase(String) - Method in interface alluxio.client.table.TableMasterClient
Syncs an existing database in the catalog master.
syncDatabase(SyncDatabasePRequest, StreamObserver<SyncDatabasePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Sync existing database into the catalog
syncDatabase(SyncDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Sync existing database into the catalog
syncDatabase(SyncDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Sync existing database into the catalog
syncDatabase(SyncDatabasePRequest, StreamObserver<SyncDatabasePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Sync existing database into the catalog
SyncDatabasePRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.SyncDatabasePRequest
SyncDatabasePRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.SyncDatabasePRequest
SyncDatabasePRequestOrBuilder - Interface in alluxio.grpc.table
 
SyncDatabasePResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.SyncDatabasePResponse
SyncDatabasePResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.SyncDatabasePResponse
SyncDatabasePResponseOrBuilder - Interface in alluxio.grpc.table
 
Syncing_VALUE - Static variable in enum alluxio.grpc.SyncPointStatus
Syncing = 1;
SYNCINTERVALMS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemMasterCommonPOptions
 
SYNCPARENTNEXTTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
 
syncPersistExistingDirectory(Supplier<JournalContext>, InodeDirectoryView, boolean) - Method in class alluxio.master.file.meta.InodeTree
Synchronously persists an inode directory to the UFS.
syncPersistNewDirectory(MutableInodeDirectory, CreatePathContext<?, ?>) - Method in class alluxio.master.file.meta.InodeTree
Synchronously persists an inode directory to the UFS.
SYNCPOINT_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddSyncPointEntry
 
SYNCPOINT_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
SyncPointStatus - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.SyncPointStatus
SyncStatus - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.SyncStatus
SyncStatus.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.SyncStatus
SyncStatusOrBuilder - Interface in alluxio.grpc.table
 
syncSuccess() - Method in class alluxio.master.file.meta.SyncCheck
This method should be called if the sync was performed successfully.
SYSTEM - Static variable in class alluxio.time.TimeContext
 
SYSTEM_PROPERTY - Static variable in class alluxio.conf.Source
 
SYSTEM_VALUE - Static variable in enum alluxio.grpc.JobSource
SYSTEM = 3;
SystemClock - Class in alluxio.clock
A clock representing the current time as reported by the operating system.
SystemClock() - Constructor for class alluxio.clock.SystemClock
Constructs a new Clock which reports the actual time.
SystemUserGroupAuthPolicy - Class in alluxio.fuse.auth
The system user group authentication policy that always set the user group to the actual end user.

T

TABLE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetAllTablesPResponse
 
TABLE_INFO_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTablePResponse
 
TABLE_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
TABLE_MASTER_CLIENT_SERVICE = 14;
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.GetTablePRequest
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ReadTablePRequest
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformJobInfo
 
TABLE_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TransformTablePRequest
 
TableInfo - Class in alluxio.grpc.table
next available id: 12
TableInfo.Builder - Class in alluxio.grpc.table
next available id: 12
TableInfo.TableType - Enum in alluxio.grpc.table
Protobuf enum alluxio.grpc.table.TableInfo.TableType
TableInfoOrBuilder - Interface in alluxio.grpc.table
 
TableMasterClient - Interface in alluxio.client.table
A client to use for interacting with a table master.
TableMasterClient.Factory - Class in alluxio.client.table
Factory for TableMasterClient.
TableMasterClientServiceGrpc - Class in alluxio.grpc.table
This interface contains table master service endpoints for Alluxio clients.
TableMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc.table
This interface contains table master service endpoints for Alluxio clients.
TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub - Class in alluxio.grpc.table
A stub to allow clients to do synchronous rpc calls to service TableMasterClientService.
TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub - Class in alluxio.grpc.table
A stub to allow clients to do ListenableFuture-style rpc calls to service TableMasterClientService.
TableMasterClientServiceGrpc.TableMasterClientServiceImplBase - Class in alluxio.grpc.table
Base class for the server implementation of the service TableMasterClientService.
TableMasterClientServiceGrpc.TableMasterClientServiceStub - Class in alluxio.grpc.table
A stub to allow clients to do asynchronous rpc calls to service TableMasterClientService.
TableMasterClientServiceImplBase() - Constructor for class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceImplBase
 
TableMasterProto - Class in alluxio.grpc.table
 
TABLES_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
TABLES_ERRORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncStatus
 
TABLES_IGNORED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncStatus
 
TABLES_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
TABLES_REMOVED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncStatus
 
TABLES_UNCHANGED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncStatus
 
TABLES_UPDATED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.SyncStatus
 
TableValidationTask - Class in alluxio.cli.hms
A task which validates table information and schemas can be obtained from the Hive Metastore.
TableValidationTask(String, String, MetastoreValidationTask<?, IMetaStoreClient>) - Constructor for class alluxio.cli.hms.TableValidationTask
Create a new metastore validation task.
TAG_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsReadOptions
 
TAG_SEPARATOR - Static variable in class alluxio.metrics.Metric
 
TAG_UFS - Static variable in class alluxio.metrics.MetricInfo
 
TAG_UFS_TYPE - Static variable in class alluxio.metrics.MetricInfo
 
TAG_USER - Static variable in class alluxio.metrics.MetricInfo
 
TAGGING_CHARSET - Static variable in class alluxio.s3.S3Constants
 
TAGGING_XATTR_KEY - Static variable in class alluxio.s3.S3Constants
 
TaggingData - Class in alluxio.s3
Parsed version of the S3 tagging XML.
TaggingData() - Constructor for class alluxio.s3.TaggingData
Default constructor for jackson.
TaggingData(TaggingData.TagSet) - Constructor for class alluxio.s3.TaggingData
Create a new TaggingData.
tagHash(int, int) - Static method in class alluxio.client.file.cache.cuckoofilter.CuckooUtils
Compute the fingerprint on given hash value.
TagPosition - Class in alluxio.client.file.cache.cuckoofilter
This class represents a position of a tag.
TagPosition(int, int, CuckooStatus) - Constructor for class alluxio.client.file.cache.cuckoofilter.TagPosition
Create a tag position with given position and status.
TAGS_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
 
TAGS_PER_BUCKET - Static variable in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
TailCommand - Class in alluxio.cli.fs.command
Prints the file's last n bytes (by default, 1KB) to the console.
TailCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.TailCommand
 
take() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
takeBackup(BackupPRequest, AtomicLong) - Method in class alluxio.master.backup.AbstractBackupRole
Takes a backup on local master.
takeEmergencyBackup() - Method in class alluxio.master.AlluxioMasterProcess
 
takeEmergencyBackup() - Method in class alluxio.master.meta.DefaultMetaMaster
Overrides current backup role and forces the master to take a local backup.
takeLeadership(CuratorFramework) - Method in class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
 
takeLocalSnapshot(boolean) - Method in class alluxio.master.journal.raft.JournalStateMachine
Takes a snapshot of local state machine.
takeRecords() - Method in class alluxio.recorder.NoopRecorder
 
takeRecords() - Method in class alluxio.recorder.Recorder
Gets and clears the records recorded so far.
takeSnapshot() - Method in class alluxio.master.journal.raft.JournalStateMachine
 
TarballCheckpointFormat - Class in alluxio.master.journal.checkpoint
Format for checkpoints written as tarballs.
TarballCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.TarballCheckpointFormat
 
TarballCheckpointFormat.TarballCheckpointReader - Class in alluxio.master.journal.checkpoint
Reads a tarball-based checkpoint.
TarballCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.TarballCheckpointFormat.TarballCheckpointReader
 
TARGET_OPTION_NAME - Static variable in class alluxio.cli.LogLevel
 
TARGET_SEPARATOR - Static variable in class alluxio.cli.LogLevel
 
TARGETDIRECTORY_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPRequest
 
TargetInfo(String, int, String) - Constructor for class alluxio.cli.LogLevel.TargetInfo
Constructor.
TarGzMarshaller - Class in alluxio.util.compression
Marshall directory following the .tar.gz specification.
TarGzMarshaller() - Constructor for class alluxio.util.compression.TarGzMarshaller
 
TarUtils - Class in alluxio.cli.bundler
Utilities for generating .tar.gz files.
TarUtils() - Constructor for class alluxio.cli.bundler.TarUtils
 
TarUtils - Class in alluxio.util.compression
Utility methods for working with tar archives.
Task<V> - Class in alluxio.scheduler.job
A task that can be executed on a worker.
Task(Job, int) - Constructor for class alluxio.scheduler.job.Task
constructs Task.
Task.TaskStat - Class in alluxio.scheduler.job
Metrics and stats to track current task.
TASK_NAME - Static variable in class alluxio.cli.UnderFileSystemContractTest
 
TASK_VALUE - Static variable in enum alluxio.grpc.JobType
TASK = 2;
TASKARGS_FIELD_NUMBER - Static variable in class alluxio.grpc.RunTaskCommand
 
TaskExecutor - Class in alluxio.worker.job.task
A thread that runs the task.
TaskExecutor(long, long, RunTaskCommand, RunTaskContext, TaskExecutorManager) - Constructor for class alluxio.worker.job.task.TaskExecutor
Creates a new instance of TaskExecutor.
TaskExecutorManager - Class in alluxio.worker.job.task
Manages the task executors.
TaskExecutorManager(int, WorkerNetAddress) - Constructor for class alluxio.worker.job.task.TaskExecutorManager
Constructs a new instance of TaskExecutorManager.
TASKID_FIELD_NUMBER - Static variable in class alluxio.grpc.CancelTaskCommand
 
TASKID_FIELD_NUMBER - Static variable in class alluxio.grpc.RunTaskCommand
 
TaskInfo - Class in alluxio.job.wire
The task description.
TaskInfo() - Constructor for class alluxio.job.wire.TaskInfo
Default constructor.
TaskInfo(long, long, Status, WorkerNetAddress, Object) - Constructor for class alluxio.job.wire.TaskInfo
Constructs a new TaskInfo from jobId, taskId, Status, workerAddress, and arguments.
TaskInfo(JobInfo) - Constructor for class alluxio.job.wire.TaskInfo
Constructs from the proto format.
TASKINFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobHeartbeatPRequest
 
TASKPOOLSIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
TASKPOOLSIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.SetTaskPoolSizeCommand
 
TaskResult - Interface in alluxio.stress
This represents the result of a single stress task.
TaskResult.Aggregator<T extends TaskResult> - Interface in alluxio.stress
The interface that aggregates multiple task results into a summary.
TaskResultStatistics - Class in alluxio.stress.common
abstract class that calculate statistics forTaskResult.
TaskResultStatistics() - Constructor for class alluxio.stress.common.TaskResultStatistics
 
TaskStat() - Constructor for class alluxio.scheduler.job.Task.TaskStat
 
TaskStatus - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.block.TaskStatus
TB - Static variable in class alluxio.Constants
 
tearDown() - Method in class alluxio.fsmaster.FileSystemBase
 
tearDown() - Method in class alluxio.fsmaster.FileSystemBench.AlluxioBenchThreadState
 
tearDown(FileSystemBench.FileSystem) - Method in class alluxio.fsmaster.FileSystemBench.AsyncBenchThreadState
 
tearDown() - Method in class alluxio.fsmaster.FileSystemBench.FileSystem
 
tearDown() - Method in class alluxio.fsmaster.FileSystemBench.HadoopBenchThreadState
 
tearDown() - Method in class alluxio.fsmaster.FileSystemMasterBase
 
tearDown() - Method in class alluxio.fsmaster.FileSystemMasterBench.FileSystem
 
tearDown() - Method in class alluxio.invalidation.cache.InvalidationSyncCacheBench.ThreadState
 
tearDown() - Method in class alluxio.snapshot.SnapshotBench.Snapshot
 
tearDownIteration() - Method in class alluxio.snapshot.SnapshotBench.Snapshot
 
TEMP_DIR - Static variable in class alluxio.client.file.cache.store.LocalPageStore
 
TEMP_UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
TEMP_UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
TempBlockMeta - Interface in alluxio.worker.block.meta
Represents the metadata of an uncommitted block in Alluxio managed storage.
temporaryFileName(long, String) - Static method in class alluxio.util.io.PathUtils
Generates a deterministic temporary file name for the a path and a file id and a nonce.
TEMPUFSPATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
TEST_ARTIFACTS_DIR - Static variable in class alluxio.Constants
 
TEST_DEPRECATED_KEY - Static variable in class alluxio.conf.PropertyKey
Deprecated.
This key is used for testing. It is always deprecated.
TEST_DIRECTORY_NAME - Static variable in class alluxio.cli.TestRunner
Directory for the test generated files.
TEST_LOG_DIR - Static variable in class alluxio.Constants
 
TEST_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
TEST_MODE - Static variable in class alluxio.conf.PropertyKey
 
testAllCornerCases() - Method in class alluxio.PositionReaderTest
Tests all corner cases.
testCallAndReturn(RpcUtilsBench.BenchParams) - Method in class alluxio.RpcUtilsBench
 
TestCommand - Class in alluxio.cli.fs.command
Tests properties of the path specified in args.
TestCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.TestCommand
 
testMethod(DoraMetaBench.Db, DoraMetaBench.ThreadState, Blackhole) - Method in class alluxio.dora.meta.DoraMetaBench
 
testMethod(InodeBenchRead.Db, InodeBenchRead.ThreadState, Blackhole) - Method in class alluxio.inode.InodeBenchRead
 
testMethod(InodeBenchWrite.Db, InodeBenchWrite.ThreadState) - Method in class alluxio.inode.InodeBenchWrite
 
testMethod(RocksBenchRead.Db, RocksBenchRead.ThreadState, Blackhole) - Method in class alluxio.inode.RocksBenchRead
 
testMethod(RocksBenchReadWrite.Db, RocksBenchReadWrite.ThreadState, Blackhole) - Method in class alluxio.inode.RocksBenchReadWrite
 
testMethod(RocksBenchWrite.Db, RocksBenchWrite.ThreadState) - Method in class alluxio.inode.RocksBenchWrite
 
TestOp - Interface in alluxio.master.backcompat
A test operation for use by the backwards compatibility test.
testReadRandomPart() - Method in class alluxio.PositionReaderTest
Tests read random parts.
TestRunner - Class in alluxio.cli
Driver to run Alluxio tests.
TestRunner.WorkerAddressConverter - Class in alluxio.cli
Parses worker address param.
TESTS_LOG - Static variable in class alluxio.Constants
 
TestUtils - Class in alluxio.master
Test utilities.
TestUtils() - Constructor for class alluxio.master.TestUtils
 
TEXT_VALUE - Static variable in enum alluxio.grpc.JobProgressReportFormat
TEXT = 1;
thenAccept(Consumer<? super T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAccept(Consumer<? super T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed with this stage's result as the argument to the supplied action.
thenAcceptAsync(Consumer<? super T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptAsync(Consumer<? super T>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptAsync(Consumer<? super T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using this stage's default asynchronous execution facility, with this stage's result as the argument to the supplied action.
thenAcceptAsync(Consumer<? super T>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using the supplied Executor, with this stage's result as the argument to the supplied action.
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed with the two results as arguments to the supplied action.
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using this stage's default asynchronous execution facility, with the two results as arguments to the supplied action.
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using the supplied executor, with the two results as arguments to the supplied action.
thenApply(Function<? super T, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenApply(Function<? super T, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed with this stage's result as the argument to the supplied function.
thenApplyAsync(Function<? super T, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenApplyAsync(Function<? super T, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using this stage's default asynchronous execution facility, with this stage's result as the argument to the supplied function.
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using the supplied Executor, with this stage's result as the argument to the supplied function.
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed with the two results as arguments to the supplied function.
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using this stage's default asynchronous execution facility, with the two results as arguments to the supplied function.
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using the supplied executor, with the two results as arguments to the supplied function.
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that is completed with the same value as the CompletionStage returned by the given function.
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that is completed with the same value as the CompletionStage returned by the given function, executed using this stage's default asynchronous execution facility.
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that is completed with the same value as the CompletionStage returned by the given function, executed using the supplied Executor.
thenRun(Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenRun(Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, executes the given action.
thenRunAsync(Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenRunAsync(Runnable, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenRunAsync(Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, executes the given action using this stage's default asynchronous execution facility.
thenRunAsync(Runnable, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, executes the given action using the supplied Executor.
THREAD_OPTION - Static variable in class alluxio.cli.fs.command.CpCommand
 
ThreadCountResult() - Constructor for class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
Creates an instance.
ThreadFactoryUtils - Class in alluxio.util
Utility methods for the ThreadFactory class.
ThreadPoolExecutorQueueType - Enum in alluxio.executor
Internal task queue type for ThreadPoolExecutor.
THREADS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStateLockHoldersPResponse
 
ThreadSleeper - Class in alluxio.time
A sleeping utility which delegates to Thread.sleep().
ThreadState() - Constructor for class alluxio.dora.meta.DoraMetaBench.ThreadState
 
ThreadState() - Constructor for class alluxio.fsmaster.FileSystemBench.ThreadState
 
ThreadState() - Constructor for class alluxio.fsmaster.FileSystemMasterBench.ThreadState
 
ThreadState() - Constructor for class alluxio.inode.InodeBenchRead.ThreadState
 
ThreadState() - Constructor for class alluxio.inode.InodeBenchWrite.ThreadState
 
ThreadState() - Constructor for class alluxio.inode.RocksBenchRead.ThreadState
 
ThreadState() - Constructor for class alluxio.inode.RocksBenchReadWrite.ThreadState
 
ThreadState() - Constructor for class alluxio.inode.RocksBenchWrite.ThreadState
 
ThreadState() - Constructor for class alluxio.invalidation.cache.InvalidationSyncCacheBench.ThreadState
 
ThreadUtils - Class in alluxio.util
Utility method for working with threads.
throttle() - Method in class alluxio.worker.job.task.TaskExecutorManager
Throttle the TaskExecutorManager.
THROUGH_VALUE - Static variable in enum alluxio.grpc.WritePType
THROUGH = 4;
throwIfCancelled() - Method in class alluxio.master.file.RpcContext
Throws RuntimeException if the RPC was cancelled by any tracker.
tick() - Method in interface alluxio.heartbeat.HeartbeatTimer
Waits until next heartbeat should be executed.
tick() - Method in class alluxio.heartbeat.ScheduledTimer
 
tick() - Method in class alluxio.heartbeat.SleepingTimer
Enforces the thread waits for the given interval between consecutive ticks.
tick() - Method in class alluxio.time.ExponentialTimer
Attempts to perform a timer tick.
tick(long) - Method in class alluxio.util.executor.ControllableQueue
Jumps to a future time period.
TIER - Static variable in class alluxio.metrics.MetricInfo
 
TIER_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
TIER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
TIER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
TIER_FIELD_NUMBER - Static variable in class alluxio.proto.meta.Block.BlockLocation
 
tierAlias() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the storage tier alias of the location.
TIERALIAS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockLocation
 
TIERALIAS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockStoreLocationProto
 
TIERALIAS_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
TierList - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.TierList
TierList.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.TierList
TierListOrBuilder - Interface in alluxio.grpc
 
TIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.TierList
 
TIME_99_COUNT - Static variable in class alluxio.stress.StressConstants
 
TIME_FORMATTER - Static variable in class alluxio.s3.S3Constants
 
TIME_HISTOGRAM_COMPRESSION_LEVEL - Static variable in class alluxio.stress.StressConstants
 
TIME_HISTOGRAM_MAX - Static variable in class alluxio.stress.StressConstants
The response time histogram can record values up to this amount.
TIME_HISTOGRAM_PRECISION - Static variable in class alluxio.stress.StressConstants
 
TimeBoundedRetry - Class in alluxio.retry
Retry mechanism which performs retries until a certain period of time has elapsed.
TimeBoundedRetry(TimeContext, Duration) - Constructor for class alluxio.retry.TimeBoundedRetry
 
TimeBoundPageStore - Class in alluxio.client.file.cache
A wrapper class on PageStore with timeout.
TimeBoundPageStore(PageStore, PageStoreOptions) - Constructor for class alluxio.client.file.cache.TimeBoundPageStore
 
TimeContext - Class in alluxio.time
Context for managing time.
TimeContext(Clock, Sleeper) - Constructor for class alluxio.time.TimeContext
 
TIMEEXPRESSION_FIELD_NUMBER - Static variable in class alluxio.grpc.AddPolicyPOptions
 
timeout() - Method in class alluxio.SessionInfo
Checks whether the session has timed out.
TimeoutRefresh - Class in alluxio.refresh
A refresh policy which allows refreshing after a specified timeout is reached.
TimeoutRefresh(long) - Constructor for class alluxio.refresh.TimeoutRefresh
Constructs a refresh facility which allows refreshing after a specified timeout is reached.
TimeoutRetry - Class in alluxio.retry
A retry policy which allows retrying until a specified timeout is reached.
TimeoutRetry(long, int) - Constructor for class alluxio.retry.TimeoutRetry
Constructs a retry facility which allows retrying until a specified timeout is reached.
TimePredicate - Class in alluxio.master.predicate
A predicate related to timestamps of the path.
TimePredicate(String, String, Function<FileInfo, Long>) - Constructor for class alluxio.master.predicate.TimePredicate
Creates an instance.
TimePredicate.DateFromFileNameOlderThanFactory - Class in alluxio.master.predicate
Factory for file name time predicate.
TimePredicate.Factory - Class in alluxio.master.predicate
Factory for creating instances.
TimePredicate.UnmodifiedForFactory - Class in alluxio.master.predicate
Factory for modification time predicate.
timer(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add timer with the given name.
TIMER_VALUE - Static variable in enum alluxio.grpc.MetricType
TIMER represents a histogram of the rate of the specified events.
TimeSeries - Class in alluxio.job.util
Class to record a time series, e.g.
TimeSeries(long) - Constructor for class alluxio.job.util.TimeSeries
Creates a TimeSeries instance with given width.
TimeSeries() - Constructor for class alluxio.job.util.TimeSeries
Creates a TimeSeries instance with default width set to 1 second.
TimeSeries - Class in alluxio.metrics
Represents a time series which can be graphed in the UI.
TimeSeries(String) - Constructor for class alluxio.metrics.TimeSeries
Create a new time series with the given name and no data.
TimeSeries.DataPoint - Class in alluxio.metrics
Represents a datapoint in a time series.
TimeSeries.Summary - Class in alluxio.job.util
Class contains the summary of the TimeSeries.
TimeSeriesStore - Class in alluxio.master.metrics
An in-memory time series store for Alluxio metrics.
TimeSeriesStore() - Constructor for class alluxio.master.metrics.TimeSeriesStore
Constructs a new time series store.
TMP_DIRS - Static variable in class alluxio.conf.PropertyKey.Name
 
TMP_DIRS - Static variable in class alluxio.conf.PropertyKey
 
toAclActions() - Method in enum alluxio.security.authorization.Mode.Bits
 
toAclActionSet() - Method in enum alluxio.security.authorization.Mode.Bits
 
toAlluxioConf(Configuration) - Static method in class alluxio.hadoop.HadoopUtils
 
toAlluxioException() - Method in exception alluxio.exception.status.AlluxioStatusException
 
toArray() - Method in class alluxio.collections.ConcurrentHashSet
 
toArray(E[]) - Method in class alluxio.collections.ConcurrentHashSet
 
toArray() - Method in class alluxio.collections.DelegatingSet
 
toArray(T1[]) - Method in class alluxio.collections.DelegatingSet
 
toArray() - Method in class alluxio.collections.UnmodifiableArrayList
 
toArray(T1[]) - Method in class alluxio.collections.UnmodifiableArrayList
 
toAuthority() - Method in interface alluxio.master.MasterInquireClient.ConnectDetails
 
toAuthority() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
toAuthority() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
toAuthority() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
toBatchTaskArgumentString() - Method in class alluxio.stress.BaseParameters
 
toBenchSummaryStatistics() - Method in class alluxio.stress.common.TaskResultStatistics
Converts this class to SummaryStatistics.
ToBePersistedFileIds - Class in alluxio.master.file.meta
Keeps track of which files are in the TO_BE_PERSISTED persistence state.
ToBePersistedFileIds() - Constructor for class alluxio.master.file.meta.ToBePersistedFileIds
 
toBlockStoreLocation() - Method in interface alluxio.worker.block.meta.StorageDir
 
toBucketS3Exception(Exception, String) - Static method in class alluxio.proxy.s3.S3RestUtils
Convert an exception to instance of S3Exception.
toBucketS3Exception(Exception, String, S3AuditContext) - Static method in class alluxio.proxy.s3.S3RestUtils
Convert an exception to instance of S3Exception.
toBucketS3Exception(Exception, String, S3AuditContext) - Static method in class alluxio.s3.NettyRestUtils
Convert an exception to instance of S3Exception.
toBuilder() - Method in class alluxio.grpc.ActionInfo
 
toBuilder() - Method in class alluxio.grpc.AddPolicyPOptions
 
toBuilder() - Method in class alluxio.grpc.AddPolicyPRequest
 
toBuilder() - Method in class alluxio.grpc.AddPolicyPResponse
 
toBuilder() - Method in class alluxio.grpc.AddQuorumServerRequest
 
toBuilder() - Method in class alluxio.grpc.AsyncCacheRequest
 
toBuilder() - Method in class alluxio.grpc.AsyncCacheResponse
 
toBuilder() - Method in class alluxio.grpc.BackupPOptions
 
toBuilder() - Method in class alluxio.grpc.BackupPRequest
 
toBuilder() - Method in class alluxio.grpc.BackupPStatus
 
toBuilder() - Method in class alluxio.grpc.BackupStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.Block
 
toBuilder() - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
toBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
toBuilder() - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
toBuilder() - Method in class alluxio.grpc.BlockIdList
 
toBuilder() - Method in class alluxio.grpc.BlockInfo
 
toBuilder() - Method in class alluxio.grpc.BlockLocation
 
toBuilder() - Method in class alluxio.grpc.BlockMasterInfo
 
toBuilder() - Method in class alluxio.grpc.BlockStatus
 
toBuilder() - Method in class alluxio.grpc.BlockStoreLocationProto
 
toBuilder() - Method in class alluxio.grpc.BuildVersion
 
toBuilder() - Method in class alluxio.grpc.CacheRequest
 
toBuilder() - Method in class alluxio.grpc.CacheResponse
 
toBuilder() - Method in class alluxio.grpc.CancelPOptions
 
toBuilder() - Method in class alluxio.grpc.CancelPRequest
 
toBuilder() - Method in class alluxio.grpc.CancelPResponse
 
toBuilder() - Method in class alluxio.grpc.CancelTaskCommand
 
toBuilder() - Method in class alluxio.grpc.CheckAccessPOptions
 
toBuilder() - Method in class alluxio.grpc.CheckAccessPRequest
 
toBuilder() - Method in class alluxio.grpc.CheckAccessPResponse
 
toBuilder() - Method in class alluxio.grpc.CheckConsistencyPOptions
 
toBuilder() - Method in class alluxio.grpc.CheckConsistencyPRequest
 
toBuilder() - Method in class alluxio.grpc.CheckConsistencyPResponse
 
toBuilder() - Method in class alluxio.grpc.CheckpointPOptions
 
toBuilder() - Method in class alluxio.grpc.CheckpointPResponse
 
toBuilder() - Method in class alluxio.grpc.CheckRequest
 
toBuilder() - Method in class alluxio.grpc.CheckResponse
 
toBuilder() - Method in class alluxio.grpc.Chunk
 
toBuilder() - Method in class alluxio.grpc.ClearMetricsPRequest
 
toBuilder() - Method in class alluxio.grpc.ClearMetricsPResponse
 
toBuilder() - Method in class alluxio.grpc.ClearMetricsRequest
 
toBuilder() - Method in class alluxio.grpc.ClearMetricsResponse
 
toBuilder() - Method in class alluxio.grpc.ClientMetrics
 
toBuilder() - Method in class alluxio.grpc.CmdProgress
 
toBuilder() - Method in class alluxio.grpc.CmdStatusBlock
 
toBuilder() - Method in class alluxio.grpc.CmdSummary
 
toBuilder() - Method in class alluxio.grpc.Command
 
toBuilder() - Method in class alluxio.grpc.CommitBlockPOptions
 
toBuilder() - Method in class alluxio.grpc.CommitBlockPRequest
 
toBuilder() - Method in class alluxio.grpc.CommitBlockPResponse
 
toBuilder() - Method in class alluxio.grpc.CompleteFilePOptions
 
toBuilder() - Method in class alluxio.grpc.CompleteFilePRequest
 
toBuilder() - Method in class alluxio.grpc.CompleteFilePResponse
 
toBuilder() - Method in class alluxio.grpc.ConfigCheckReport
 
toBuilder() - Method in class alluxio.grpc.ConfigProperties
 
toBuilder() - Method in class alluxio.grpc.ConfigProperty
 
toBuilder() - Method in class alluxio.grpc.CopyJobPOptions
 
toBuilder() - Method in class alluxio.grpc.CopyRequest
 
toBuilder() - Method in class alluxio.grpc.CopyResponse
 
toBuilder() - Method in class alluxio.grpc.CreateDirectoryPOptions
 
toBuilder() - Method in class alluxio.grpc.CreateDirectoryPRequest
 
toBuilder() - Method in class alluxio.grpc.CreateDirectoryPResponse
 
toBuilder() - Method in class alluxio.grpc.CreateFilePOptions
 
toBuilder() - Method in class alluxio.grpc.CreateFilePRequest
 
toBuilder() - Method in class alluxio.grpc.CreateFilePResponse
 
toBuilder() - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
toBuilder() - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
toBuilder() - Method in class alluxio.grpc.DeletePOptions
 
toBuilder() - Method in class alluxio.grpc.DeletePRequest
 
toBuilder() - Method in class alluxio.grpc.DeletePResponse
 
toBuilder() - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.ErrorInfo
 
toBuilder() - Method in class alluxio.grpc.ExistsPOptions
 
toBuilder() - Method in class alluxio.grpc.ExistsPRequest
 
toBuilder() - Method in class alluxio.grpc.ExistsPResponse
 
toBuilder() - Method in class alluxio.grpc.File
 
toBuilder() - Method in class alluxio.grpc.FileBlockInfo
 
toBuilder() - Method in class alluxio.grpc.FileFailure
 
toBuilder() - Method in class alluxio.grpc.FileInfo
 
toBuilder() - Method in class alluxio.grpc.FileSystemCommand
 
toBuilder() - Method in class alluxio.grpc.FileSystemCommandOptions
 
toBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
toBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
toBuilder() - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
toBuilder() - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
toBuilder() - Method in class alluxio.grpc.FreePOptions
 
toBuilder() - Method in class alluxio.grpc.FreePRequest
 
toBuilder() - Method in class alluxio.grpc.FreePResponse
 
toBuilder() - Method in class alluxio.grpc.FreeWorkerRequest
 
toBuilder() - Method in class alluxio.grpc.FreeWorkerResponse
 
toBuilder() - Method in class alluxio.grpc.FsOpPId
 
toBuilder() - Method in class alluxio.grpc.GetActionInfoOptions
 
toBuilder() - Method in class alluxio.grpc.GetActionInfoRequest
 
toBuilder() - Method in class alluxio.grpc.GetActionInfoResponse
 
toBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
toBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
toBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
toBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
toBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
toBuilder() - Method in class alluxio.grpc.GetBlockInfoPOptions
 
toBuilder() - Method in class alluxio.grpc.GetBlockInfoPRequest
 
toBuilder() - Method in class alluxio.grpc.GetBlockInfoPResponse
 
toBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
toBuilder() - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
toBuilder() - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
toBuilder() - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
toBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
toBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
toBuilder() - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
toBuilder() - Method in class alluxio.grpc.GetCmdStatusOptions
 
toBuilder() - Method in class alluxio.grpc.GetCmdStatusRequest
 
toBuilder() - Method in class alluxio.grpc.GetCmdStatusResponse
 
toBuilder() - Method in class alluxio.grpc.GetConfigHashPOptions
 
toBuilder() - Method in class alluxio.grpc.GetConfigHashPResponse
 
toBuilder() - Method in class alluxio.grpc.GetConfigReportPOptions
 
toBuilder() - Method in class alluxio.grpc.GetConfigReportPResponse
 
toBuilder() - Method in class alluxio.grpc.GetConfigurationPOptions
 
toBuilder() - Method in class alluxio.grpc.GetConfigurationPResponse
 
toBuilder() - Method in class alluxio.grpc.GetFileInfoPOptions
 
toBuilder() - Method in class alluxio.grpc.GetFileInfoPRequest
 
toBuilder() - Method in class alluxio.grpc.GetFileInfoPResponse
 
toBuilder() - Method in class alluxio.grpc.GetFilePathPRequest
 
toBuilder() - Method in class alluxio.grpc.GetFilePathPResponse
 
toBuilder() - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
toBuilder() - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
toBuilder() - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
toBuilder() - Method in class alluxio.grpc.GetJobProgressPRequest
 
toBuilder() - Method in class alluxio.grpc.GetJobProgressPResponse
 
toBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
toBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
toBuilder() - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
toBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
toBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
toBuilder() - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
toBuilder() - Method in class alluxio.grpc.GetJobStatusPOptions
 
toBuilder() - Method in class alluxio.grpc.GetJobStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.GetJobStatusPResponse
 
toBuilder() - Method in class alluxio.grpc.GetMasterIdPOptions
 
toBuilder() - Method in class alluxio.grpc.GetMasterIdPRequest
 
toBuilder() - Method in class alluxio.grpc.GetMasterIdPResponse
 
toBuilder() - Method in class alluxio.grpc.GetMasterInfoPOptions
 
toBuilder() - Method in class alluxio.grpc.GetMasterInfoPResponse
 
toBuilder() - Method in class alluxio.grpc.GetMetricsPOptions
 
toBuilder() - Method in class alluxio.grpc.GetMetricsPResponse
 
toBuilder() - Method in class alluxio.grpc.GetMountIdPRequest
 
toBuilder() - Method in class alluxio.grpc.GetMountIdPResponse
 
toBuilder() - Method in class alluxio.grpc.GetMountTablePRequest
 
toBuilder() - Method in class alluxio.grpc.GetMountTablePResponse
 
toBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
toBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
toBuilder() - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
toBuilder() - Method in class alluxio.grpc.GetNodeStatePRequest
 
toBuilder() - Method in class alluxio.grpc.GetNodeStatePResponse
 
toBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
toBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
toBuilder() - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
toBuilder() - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
toBuilder() - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
toBuilder() - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
toBuilder() - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
toBuilder() - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
toBuilder() - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
toBuilder() - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
toBuilder() - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
toBuilder() - Method in class alluxio.grpc.GetServiceVersionPRequest
 
toBuilder() - Method in class alluxio.grpc.GetServiceVersionPResponse
 
toBuilder() - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
toBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
toBuilder() - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
toBuilder() - Method in class alluxio.grpc.GetStatusPOptions
 
toBuilder() - Method in class alluxio.grpc.GetStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.GetStatusPResponse
 
toBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
toBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
toBuilder() - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
toBuilder() - Method in class alluxio.grpc.GetUfsInfoPOptions
 
toBuilder() - Method in class alluxio.grpc.GetUfsInfoPRequest
 
toBuilder() - Method in class alluxio.grpc.GetUfsInfoPResponse
 
toBuilder() - Method in class alluxio.grpc.GetUsedBytesPOptions
 
toBuilder() - Method in class alluxio.grpc.GetUsedBytesPResponse
 
toBuilder() - Method in class alluxio.grpc.GetWorkerIdPOptions
 
toBuilder() - Method in class alluxio.grpc.GetWorkerIdPRequest
 
toBuilder() - Method in class alluxio.grpc.GetWorkerIdPResponse
 
toBuilder() - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
toBuilder() - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
toBuilder() - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
toBuilder() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
toBuilder() - Method in class alluxio.grpc.GetWorkerReportPOptions
 
toBuilder() - Method in class alluxio.grpc.InconsistentProperties
 
toBuilder() - Method in class alluxio.grpc.InconsistentProperty
 
toBuilder() - Method in class alluxio.grpc.InconsistentPropertyValues
 
toBuilder() - Method in class alluxio.grpc.JobCommand
 
toBuilder() - Method in class alluxio.grpc.JobDescription
 
toBuilder() - Method in class alluxio.grpc.JobHeartbeatPOptions
 
toBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest
 
toBuilder() - Method in class alluxio.grpc.JobHeartbeatPResponse
 
toBuilder() - Method in class alluxio.grpc.JobInfo
 
toBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
toBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
toBuilder() - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
toBuilder() - Method in class alluxio.grpc.JobMasterStatus
 
toBuilder() - Method in class alluxio.grpc.JobProgress
 
toBuilder() - Method in class alluxio.grpc.JobProgressPOptions
 
toBuilder() - Method in class alluxio.grpc.JobServiceSummary
 
toBuilder() - Method in class alluxio.grpc.JobStatusBlock
 
toBuilder() - Method in class alluxio.grpc.JobUnused
 
toBuilder() - Method in class alluxio.grpc.JobWorkerHealth
 
toBuilder() - Method in class alluxio.grpc.JournalQueryRequest
 
toBuilder() - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
toBuilder() - Method in class alluxio.grpc.ListAllPOptions
 
toBuilder() - Method in class alluxio.grpc.ListAllPRequest
 
toBuilder() - Method in class alluxio.grpc.ListAllPResponse
 
toBuilder() - Method in class alluxio.grpc.ListPolicyPOptions
 
toBuilder() - Method in class alluxio.grpc.ListPolicyPRequest
 
toBuilder() - Method in class alluxio.grpc.ListPolicyPResponse
 
toBuilder() - Method in class alluxio.grpc.ListProxyStatusPOptions
 
toBuilder() - Method in class alluxio.grpc.ListProxyStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.ListProxyStatusPResponse
 
toBuilder() - Method in class alluxio.grpc.ListStatusPartialPOptions
 
toBuilder() - Method in class alluxio.grpc.ListStatusPartialPRequest
 
toBuilder() - Method in class alluxio.grpc.ListStatusPartialPResponse
 
toBuilder() - Method in class alluxio.grpc.ListStatusPOptions
 
toBuilder() - Method in class alluxio.grpc.ListStatusPRequest
 
toBuilder() - Method in class alluxio.grpc.ListStatusPResponse
 
toBuilder() - Method in class alluxio.grpc.LoadFileFailure
 
toBuilder() - Method in class alluxio.grpc.LoadFileRequest
 
toBuilder() - Method in class alluxio.grpc.LoadFileResponse
 
toBuilder() - Method in class alluxio.grpc.LoadJobPOptions
 
toBuilder() - Method in class alluxio.grpc.LoadMetadataPOptions
 
toBuilder() - Method in class alluxio.grpc.LoadRequest
 
toBuilder() - Method in class alluxio.grpc.LoadResponse
 
toBuilder() - Method in class alluxio.grpc.LocationBlockIdListEntry
 
toBuilder() - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
toBuilder() - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
toBuilder() - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
toBuilder() - Method in class alluxio.grpc.MasterInfo
 
toBuilder() - Method in class alluxio.grpc.MasterVersion
 
toBuilder() - Method in class alluxio.grpc.MessagingRequestHeader
 
toBuilder() - Method in class alluxio.grpc.MessagingResponseHeader
 
toBuilder() - Method in class alluxio.grpc.Metric
 
toBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
toBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
toBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
toBuilder() - Method in class alluxio.grpc.MetricValue
 
toBuilder() - Method in class alluxio.grpc.MountPointInfo
 
toBuilder() - Method in class alluxio.grpc.MountPOptions
 
toBuilder() - Method in class alluxio.grpc.MountPRequest
 
toBuilder() - Method in class alluxio.grpc.MountPResponse
 
toBuilder() - Method in class alluxio.grpc.MoveBlockRequest
 
toBuilder() - Method in class alluxio.grpc.MoveBlockResponse
 
toBuilder() - Method in class alluxio.grpc.MoveJobPOptions
 
toBuilder() - Method in class alluxio.grpc.MoveRequest
 
toBuilder() - Method in class alluxio.grpc.MoveResponse
 
toBuilder() - Method in class alluxio.grpc.NeedsSyncRequest
 
toBuilder() - Method in class alluxio.grpc.NeedsSyncResponse
 
toBuilder() - Method in class alluxio.grpc.NetAddress
 
toBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
toBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
toBuilder() - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
toBuilder() - Method in class alluxio.grpc.OpenFilePOptions
 
toBuilder() - Method in class alluxio.grpc.PAcl
 
toBuilder() - Method in class alluxio.grpc.PAclEntry
 
toBuilder() - Method in class alluxio.grpc.PersistCommandOptions
 
toBuilder() - Method in class alluxio.grpc.PersistFile
 
toBuilder() - Method in class alluxio.grpc.PMode
 
toBuilder() - Method in class alluxio.grpc.PolicyInfo
 
toBuilder() - Method in class alluxio.grpc.PolicyStatus
 
toBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
toBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
toBuilder() - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
toBuilder() - Method in class alluxio.grpc.ProxyStatus
 
toBuilder() - Method in class alluxio.grpc.QuorumServerInfo
 
toBuilder() - Method in class alluxio.grpc.ReadRequest
 
toBuilder() - Method in class alluxio.grpc.ReadResponse
 
toBuilder() - Method in class alluxio.grpc.RegisterCommand
 
toBuilder() - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
toBuilder() - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
toBuilder() - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
toBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
toBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
toBuilder() - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
toBuilder() - Method in class alluxio.grpc.RegisterMasterPOptions
 
toBuilder() - Method in class alluxio.grpc.RegisterMasterPRequest
 
toBuilder() - Method in class alluxio.grpc.RegisterMasterPResponse
 
toBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions
 
toBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest
 
toBuilder() - Method in class alluxio.grpc.RegisterWorkerPResponse
 
toBuilder() - Method in class alluxio.grpc.RemoveBlockRequest
 
toBuilder() - Method in class alluxio.grpc.RemoveBlockResponse
 
toBuilder() - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
toBuilder() - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
toBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
toBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
toBuilder() - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
toBuilder() - Method in class alluxio.grpc.RemovePolicyPOptions
 
toBuilder() - Method in class alluxio.grpc.RemovePolicyPRequest
 
toBuilder() - Method in class alluxio.grpc.RemovePolicyPResponse
 
toBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
toBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
toBuilder() - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
toBuilder() - Method in class alluxio.grpc.RenamePOptions
 
toBuilder() - Method in class alluxio.grpc.RenamePRequest
 
toBuilder() - Method in class alluxio.grpc.RenamePResponse
 
toBuilder() - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
toBuilder() - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
toBuilder() - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
toBuilder() - Method in class alluxio.grpc.RetryInfo
 
toBuilder() - Method in class alluxio.grpc.ReverseResolvePRequest
 
toBuilder() - Method in class alluxio.grpc.ReverseResolvePResponse
 
toBuilder() - Method in class alluxio.grpc.Route
 
toBuilder() - Method in class alluxio.grpc.RouteFailure
 
toBuilder() - Method in class alluxio.grpc.RunPOptions
 
toBuilder() - Method in class alluxio.grpc.RunPRequest
 
toBuilder() - Method in class alluxio.grpc.RunPResponse
 
toBuilder() - Method in class alluxio.grpc.RunTaskCommand
 
toBuilder() - Method in class alluxio.grpc.S3SyntaxOptions
 
toBuilder() - Method in class alluxio.grpc.SaslMessage
 
toBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
toBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
toBuilder() - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
toBuilder() - Method in class alluxio.grpc.SetAclPOptions
 
toBuilder() - Method in class alluxio.grpc.SetAclPRequest
 
toBuilder() - Method in class alluxio.grpc.SetAclPResponse
 
toBuilder() - Method in class alluxio.grpc.SetAttributePOptions
 
toBuilder() - Method in class alluxio.grpc.SetAttributePRequest
 
toBuilder() - Method in class alluxio.grpc.SetAttributePResponse
 
toBuilder() - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
toBuilder() - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
toBuilder() - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
toBuilder() - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
toBuilder() - Method in class alluxio.grpc.SnapshotData
 
toBuilder() - Method in class alluxio.grpc.SnapshotMetadata
 
toBuilder() - Method in class alluxio.grpc.StatusSummary
 
toBuilder() - Method in class alluxio.grpc.StopJobPRequest
 
toBuilder() - Method in class alluxio.grpc.StopJobPResponse
 
toBuilder() - Method in class alluxio.grpc.StorageList
 
toBuilder() - Method in class alluxio.grpc.SubmitJobPRequest
 
toBuilder() - Method in class alluxio.grpc.SubmitJobPResponse
 
toBuilder() - Method in class alluxio.grpc.SubmitOptions
 
toBuilder() - Method in class alluxio.grpc.SubmitRequest
 
toBuilder() - Method in class alluxio.grpc.SubmitResponse
 
toBuilder() - Method in class alluxio.grpc.table.AllOrNoneSet
 
toBuilder() - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
toBuilder() - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
toBuilder() - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
toBuilder() - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
toBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsData
 
toBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
toBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsList
 
toBuilder() - Method in class alluxio.grpc.table.Constraint
 
toBuilder() - Method in class alluxio.grpc.table.Database
 
toBuilder() - Method in class alluxio.grpc.table.Date
 
toBuilder() - Method in class alluxio.grpc.table.DateColumnStatsData
 
toBuilder() - Method in class alluxio.grpc.table.Decimal
 
toBuilder() - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
toBuilder() - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
toBuilder() - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
toBuilder() - Method in class alluxio.grpc.table.Domain
 
toBuilder() - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
toBuilder() - Method in class alluxio.grpc.table.EquatableValueSet
 
toBuilder() - Method in class alluxio.grpc.table.FieldSchema
 
toBuilder() - Method in class alluxio.grpc.table.FileStatistics
 
toBuilder() - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
toBuilder() - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
toBuilder() - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
toBuilder() - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
toBuilder() - Method in class alluxio.grpc.table.GetDatabasePRequest
 
toBuilder() - Method in class alluxio.grpc.table.GetDatabasePResponse
 
toBuilder() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
toBuilder() - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
toBuilder() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
toBuilder() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
toBuilder() - Method in class alluxio.grpc.table.GetTablePRequest
 
toBuilder() - Method in class alluxio.grpc.table.GetTablePResponse
 
toBuilder() - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
toBuilder() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
toBuilder() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
toBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
toBuilder() - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
toBuilder() - Method in class alluxio.grpc.table.layout.hive.Storage
 
toBuilder() - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
toBuilder() - Method in class alluxio.grpc.table.Layout
 
toBuilder() - Method in class alluxio.grpc.table.LayoutSpec
 
toBuilder() - Method in class alluxio.grpc.table.LongColumnStatsData
 
toBuilder() - Method in class alluxio.grpc.table.Partition
 
toBuilder() - Method in class alluxio.grpc.table.PartitionSpec
 
toBuilder() - Method in class alluxio.grpc.table.Range
 
toBuilder() - Method in class alluxio.grpc.table.RangeSet
 
toBuilder() - Method in class alluxio.grpc.table.ReadTablePRequest
 
toBuilder() - Method in class alluxio.grpc.table.ReadTablePResponse
 
toBuilder() - Method in class alluxio.grpc.table.Schema
 
toBuilder() - Method in class alluxio.grpc.table.StringColumnStatsData
 
toBuilder() - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
toBuilder() - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
toBuilder() - Method in class alluxio.grpc.table.SyncStatus
 
toBuilder() - Method in class alluxio.grpc.table.TableInfo
 
toBuilder() - Method in class alluxio.grpc.table.Transformation
 
toBuilder() - Method in class alluxio.grpc.table.TransformJobInfo
 
toBuilder() - Method in class alluxio.grpc.table.TransformTablePRequest
 
toBuilder() - Method in class alluxio.grpc.table.TransformTablePResponse
 
toBuilder() - Method in class alluxio.grpc.table.Value
 
toBuilder() - Method in class alluxio.grpc.TierList
 
toBuilder() - Method in class alluxio.grpc.TransferLeaderMessage
 
toBuilder() - Method in class alluxio.grpc.TransferLeadershipPOptions
 
toBuilder() - Method in class alluxio.grpc.TransferLeadershipPRequest
 
toBuilder() - Method in class alluxio.grpc.TransferLeadershipPResponse
 
toBuilder() - Method in class alluxio.grpc.TransportMessage
 
toBuilder() - Method in class alluxio.grpc.TriggerPolicyRequest
 
toBuilder() - Method in class alluxio.grpc.TriggerPolicyResponse
 
toBuilder() - Method in class alluxio.grpc.UfsFileStatus
 
toBuilder() - Method in class alluxio.grpc.UfsInfo
 
toBuilder() - Method in class alluxio.grpc.UfsReadOptions
 
toBuilder() - Method in class alluxio.grpc.UfsStatus
 
toBuilder() - Method in class alluxio.grpc.UnmountPOptions
 
toBuilder() - Method in class alluxio.grpc.UnmountPRequest
 
toBuilder() - Method in class alluxio.grpc.UnmountPResponse
 
toBuilder() - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
toBuilder() - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
toBuilder() - Method in class alluxio.grpc.UpdateMountPRequest
 
toBuilder() - Method in class alluxio.grpc.UpdateMountPResponse
 
toBuilder() - Method in class alluxio.grpc.UpdateUfsModePOptions
 
toBuilder() - Method in class alluxio.grpc.UpdateUfsModePRequest
 
toBuilder() - Method in class alluxio.grpc.UpdateUfsModePResponse
 
toBuilder() - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
toBuilder() - Method in class alluxio.grpc.WorkerIdentity
 
toBuilder() - Method in class alluxio.grpc.WorkerInfo
 
toBuilder() - Method in class alluxio.grpc.WorkerLostStorageInfo
 
toBuilder() - Method in class alluxio.grpc.WorkerNetAddress
 
toBuilder() - Method in class alluxio.grpc.WriteOptions
 
toBuilder() - Method in class alluxio.grpc.WriteRequest
 
toBuilder() - Method in class alluxio.grpc.WriteRequestCommand
 
toBuilder() - Method in class alluxio.grpc.WriteResponse
 
toBuilder() - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
toBuilder() - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.Response
 
toBuilder() - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
toBuilder() - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
toBuilder() - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
toBuilder() - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.NewBlockEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.PersistFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.RenameEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.SetAclEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.StringPairEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
toBuilder() - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
toBuilder() - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
toBuilder() - Method in class alluxio.proto.journal.Job.FileFilter
 
toBuilder() - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
toBuilder() - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
toBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry
 
toBuilder() - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
toBuilder() - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
toBuilder() - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
toBuilder() - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
toBuilder() - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
toBuilder() - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
toBuilder() - Method in class alluxio.proto.meta.Block.BlockLocation
 
toBuilder() - Method in class alluxio.proto.meta.Block.BlockMeta
 
toBuilder() - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
toBuilder() - Method in class alluxio.proto.meta.InodeMeta.Inode
 
toBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList
 
toBuilder() - Method in class alluxio.proto.shared.Acl.AclActions
 
toBuilder() - Method in class alluxio.proto.shared.Acl.AclEntry
 
toBuilder() - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
toByteArray(long, long) - Static method in class alluxio.master.metastore.rocks.RocksUtils
 
toByteArray(long, String) - Static method in class alluxio.master.metastore.rocks.RocksUtils
 
toByteArray() - Method in class alluxio.util.proto.ProtoMessage
 
toCliString() - Method in class alluxio.security.authorization.AclActions
 
toCliString() - Method in class alluxio.security.authorization.AclEntry
 
toCliString() - Method in enum alluxio.security.authorization.AclEntryType
 
toCompletableFuture() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns this CompletableFuture.
toCompletableFuture() - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a CompletableFuture maintaining the same completion properties as this stage.
toDefault(String) - Static method in class alluxio.security.authorization.AclEntry
Convert a normal ACL to a string representing a default ACL.
toDelete() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toDisplayMountPointInfo() - Method in class alluxio.master.file.meta.options.MountInfo
 
toFsProto() - Method in class alluxio.wire.OperationId
 
toGetStatusOptions(ExistsPOptions) - Static method in class alluxio.grpc.GrpcUtils
Converts from proto type to options.
toGrpcStatusException() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
toGrpcStatusException() - Method in exception alluxio.exception.status.AlluxioStatusException
 
toGrpcStatusRuntimeException() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
toHiveLayout(Layout) - Static method in class alluxio.table.ProtoUtils
 
toIOException() - Method in exception alluxio.exception.JournalClosedException
 
toJournalClosedException() - Method in exception alluxio.exception.JournalClosedException.IOJournalClosedException
 
toJournalEntry() - Method in class alluxio.master.file.meta.Inode
 
toJournalEntry(String) - Method in class alluxio.master.file.meta.MutableInode
 
toJournalEntry() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
toJournalEntry(String) - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
toJournalEntry() - Method in class alluxio.master.file.meta.MutableInodeFile
 
toJournalEntry(String) - Method in class alluxio.master.file.meta.MutableInodeFile
 
toJournalEntry() - Method in class alluxio.master.job.CopyJob
 
toJournalEntry() - Method in class alluxio.master.job.DoraLoadJob
 
toJournalEntry() - Method in class alluxio.master.job.LoadJob
 
toJournalEntry() - Method in class alluxio.master.job.MoveJob
 
toJournalEntry() - Method in interface alluxio.master.journal.JournalEntryRepresentable
 
toJournalEntry() - Method in interface alluxio.master.journalv0.JournalEntryRepresentable
 
toJournalEntry() - Method in interface alluxio.scheduler.job.Job
 
toJournalProto() - Method in class alluxio.wire.OperationId
 
toJson(ValidationResults) - Static method in interface alluxio.cli.ValidationTool
Convert to Json format of the validation result.
toJson() - Method in class alluxio.stress.graph.Graph
 
toJson() - Method in interface alluxio.util.JsonSerializable
 
TOKEN_SEPARATOR_REGEX - Static variable in class alluxio.util.ShellUtils
Token separator regex used to parse Shell tool outputs.
toLoadMetadata() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toLong(WorkerIdentity) - Method in class alluxio.wire.WorkerIdentity.ParserV0
Converts to a numeric worker ID represented as a long.
toLower(char) - Static method in class alluxio.util.URIUtils
 
toMap() - Method in interface alluxio.conf.AlluxioConfiguration
 
toMap(ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
 
toMap() - Static method in class alluxio.conf.Configuration
 
toMap(ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
 
toMap(ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
 
toMap(ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
toModeBits() - Method in enum alluxio.security.authorization.AclAction
 
toModeBits() - Method in class alluxio.security.authorization.AclActions
 
toMountPointInfo() - Method in class alluxio.master.file.meta.options.MountInfo
 
toObjectS3Exception(Exception, String) - Static method in class alluxio.proxy.s3.S3RestUtils
Convert an exception to instance of S3Exception.
toObjectS3Exception(Exception, String, S3AuditContext) - Static method in class alluxio.proxy.s3.S3RestUtils
Convert an exception to instance of S3Exception.
toObjectS3Exception(Exception, String, S3AuditContext) - Static method in class alluxio.s3.NettyRestUtils
Convert an exception to instance of S3Exception.
tooManyPendingChunks() - Method in class alluxio.worker.grpc.FileReadHandler
 
toPath(AlluxioURI) - Static method in class alluxio.hadoop.HadoopUtils
 
toPersistConfig() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
Convert to PersistConfig.
toProto() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
toProto() - Method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
 
toProto() - Method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
 
toProto() - Method in enum alluxio.client.ReadType
 
toProto() - Method in enum alluxio.client.WriteType
 
toProto(AccessControlList) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(DefaultAccessControlList) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(AclAction) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(AclEntry) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(AclEntryType) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(BlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(BlockLocation) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(FileInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a wire type to a proto type.
toProto(FileBlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(LoadMetadataType) - Static method in class alluxio.grpc.GrpcUtils
Converts options to proto type.
toProto(DescendantType) - Static method in class alluxio.grpc.GrpcUtils
Converts options to proto type.
toProto(MountPointInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(WorkerInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(WorkerNetAddress) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(CommandType) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(PersistFile) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(FileSystemCommand) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(UfsInfo) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(long, Optional<RegisterLease>) - Static method in class alluxio.grpc.GrpcUtils
 
toProto() - Method in class alluxio.job.wire.CmdStatusBlock
Convert to proto type.
toProto() - Method in interface alluxio.job.wire.JobInfo
 
toProto() - Method in class alluxio.job.wire.JobServiceSummary
 
toProto() - Method in enum alluxio.job.wire.JobSource
 
toProto() - Method in class alluxio.job.wire.JobWorkerHealth
 
toProto() - Method in class alluxio.job.wire.PlanInfo
 
toProto() - Method in enum alluxio.job.wire.Status
 
toProto() - Method in class alluxio.job.wire.StatusSummary
 
toProto() - Method in class alluxio.job.wire.TaskInfo
 
toProto() - Method in class alluxio.job.wire.WorkflowInfo
 
toProto() - Method in class alluxio.master.file.meta.Inode
 
toProto() - Method in interface alluxio.master.file.meta.InodeView
 
toProto() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
toProto() - Method in class alluxio.master.file.meta.MutableInodeFile
 
toProto() - Method in class alluxio.metrics.Metric
 
toProto(Status) - Static method in class alluxio.network.protocol.RPCProtoMessage
Converts an internal exception status to a protocol buffer type status.
toProto(JobState) - Static method in enum alluxio.scheduler.job.JobState
Convert JobStatus to PJobStatus.
toProto() - Method in enum alluxio.security.authorization.Mode.Bits
 
toProto() - Method in class alluxio.security.authorization.Mode
 
toProto() - Method in class alluxio.underfs.UfsStatus
 
toProto(AccessControlList) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(AclActions) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(AclAction) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(AclEntry) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(SetAclAction) - Static method in class alluxio.util.proto.ProtoUtils
Converts wire type to proto type.
toProto(Status) - Static method in class alluxio.util.proto.ProtoUtils
Converts an internal exception status to a protocol buffer type status.
toProto(AclEntryType) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto() - Method in class alluxio.wire.Address
 
toProto() - Method in class alluxio.wire.BackupStatus
 
toProto() - Method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
toProto() - Method in class alluxio.wire.BlockMasterInfo
 
toProto() - Method in class alluxio.wire.ConfigCheckReport
 
toProto() - Method in class alluxio.wire.ConfigHash
 
toProto() - Method in class alluxio.wire.Configuration
 
toProto() - Method in class alluxio.wire.InconsistentProperty
 
toProto() - Method in class alluxio.wire.Property
 
toProto(WorkerIdentity) - Static method in class alluxio.wire.WorkerIdentity.Parsers
Converts to a Protobuf representation.
toProto() - Method in class alluxio.wire.WorkerIdentity
Converts to Protobuf representation.
toProto() - Method in class alluxio.worker.block.BlockStoreLocation
Fill BlockStoreLocationproto with location information.
toProtobuf(TtlAction) - Static method in class alluxio.master.ProtobufUtils
Converts Wire type to Protobuf type.
toProtoBuilder() - Method in class alluxio.master.file.meta.MutableInode
 
toResponse(Throwable) - Method in class alluxio.proxy.s3.S3RestExceptionMapper
convert the Exception to the HTTP Response for jersey.
toS3Date(long) - Static method in class alluxio.proxy.s3.S3RestUtils
 
toS3Date(long) - Static method in class alluxio.RestUtils
 
toShort() - Method in class alluxio.security.authorization.Mode
Encodes the object as a short.
toString() - Method in class alluxio.AlluxioURI
Illegal characters unescaped in the string, for glob processing, etc.
toString() - Method in class alluxio.cli.LogLevel.TargetInfo
 
toString() - Method in class alluxio.cli.ValidationTaskResult
 
toString() - Method in class alluxio.client.block.BlockWorkerInfo
 
toString() - Method in class alluxio.client.block.options.GetWorkerReportOptions
 
toString() - Method in class alluxio.client.file.cache.CacheUsage.DirPartition
 
toString() - Method in class alluxio.client.file.cache.CacheUsage.FilePartition
 
toString() - Method in class alluxio.client.file.cache.CacheUsage.ScopePartition
 
toString() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
toString() - Method in class alluxio.client.file.cache.cuckoofilter.TagPosition
 
toString() - Method in class alluxio.client.file.cache.PageId
 
toString() - Method in class alluxio.client.file.cache.PageInfo
 
toString() - Method in class alluxio.client.file.CacheContext
 
toString() - Method in class alluxio.client.file.FileSystemContext.ClientPoolKey
 
toString() - Method in class alluxio.client.file.options.InStreamOptions
 
toString() - Method in class alluxio.client.file.options.OutStreamOptions
 
toString() - Method in class alluxio.client.file.options.UfsFileSystemOptions
 
toString() - Method in class alluxio.client.file.URIStatus
 
toString() - Method in class alluxio.client.hive.HiveCacheContext
 
toString() - Method in class alluxio.client.quota.CacheScope
 
toString() - Method in class alluxio.collections.ConcurrentHashSet
 
toString() - Method in class alluxio.collections.LockPool
 
toString() - Method in class alluxio.collections.Pair
 
toString() - Method in class alluxio.collections.PrefixList
Print out all prefixes separated by ";".
toString() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a string identifying this CompletableFuture, as well as its completion state.
toString() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
toString() - Method in class alluxio.conf.PropertyKey.Builder
 
toString() - Method in enum alluxio.conf.PropertyKey.Template
 
toString() - Method in class alluxio.conf.PropertyKey
 
toString() - Method in class alluxio.conf.Source
 
toString() - Method in exception alluxio.exception.AggregateException
 
toString() - Method in enum alluxio.exception.PreconditionMessage
 
toString() - Method in enum alluxio.executor.ExecutorServiceBuilder.RpcExecutorHost
 
toString() - Method in class alluxio.grpc.GrpcChannelKey
 
toString() - Method in class alluxio.grpc.GrpcServer
 
toString() - Method in class alluxio.grpc.GrpcServerAddress
 
toString() - Method in enum alluxio.jnifuse.constants.Errno
 
toString() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
toString() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
toString() - Method in class alluxio.job.CopyJobRequest
 
toString() - Method in class alluxio.job.JobDescription
 
toString() - Method in class alluxio.job.LoadJobRequest
 
toString() - Method in class alluxio.job.MasterWorkerInfo
 
toString() - Method in class alluxio.job.MoveJobRequest
 
toString() - Method in class alluxio.job.plan.batch.BatchedJobDefinition.BatchedJobTask
 
toString() - Method in class alluxio.job.plan.BatchedJobConfig
 
toString() - Method in class alluxio.job.plan.migrate.MigrateCommand
 
toString() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
toString() - Method in class alluxio.job.plan.NoopPlanConfig
 
toString() - Method in class alluxio.job.plan.persist.PersistConfig
 
toString() - Method in class alluxio.job.plan.replicate.MoveConfig
 
toString() - Method in class alluxio.job.util.TimeSeries
 
toString() - Method in class alluxio.job.wire.JobServiceSummary
 
toString() - Method in class alluxio.job.wire.JobWorkerHealth
 
toString() - Method in class alluxio.job.wire.PlanInfo
 
toString() - Method in class alluxio.job.wire.StatusSummary
 
toString() - Method in class alluxio.job.wire.TaskInfo
 
toString() - Method in class alluxio.job.wire.WorkflowInfo
 
toString() - Method in class alluxio.job.workflow.composite.CompositeConfig
 
toString() - Method in class alluxio.master.AlluxioMasterProcess
 
toString() - Method in class alluxio.master.AlluxioSimpleMasterProcess
 
toString() - Method in class alluxio.master.backcompat.Version
 
toString() - Method in class alluxio.master.backup.BackupHandshakeMessage
 
toString() - Method in class alluxio.master.backup.BackupHeartbeatMessage
 
toString() - Method in class alluxio.master.backup.BackupRequestMessage
 
toString() - Method in class alluxio.master.backup.BackupSuspendMessage
 
toString() - Method in class alluxio.master.block.meta.MasterBlockLocation
 
toString() - Method in class alluxio.master.block.meta.MasterWorkerInfo
 
toString() - Method in class alluxio.master.file.contexts.CheckAccessContext
 
toString() - Method in class alluxio.master.file.contexts.CheckConsistencyContext
 
toString() - Method in class alluxio.master.file.contexts.CompleteFileContext
 
toString() - Method in class alluxio.master.file.contexts.CreateDirectoryContext
 
toString() - Method in class alluxio.master.file.contexts.CreateFileContext
 
toString() - Method in class alluxio.master.file.contexts.CreatePathContext
 
toString() - Method in class alluxio.master.file.contexts.DeleteContext
 
toString() - Method in class alluxio.master.file.contexts.ExistsContext
 
toString() - Method in class alluxio.master.file.contexts.FreeContext
 
toString() - Method in class alluxio.master.file.contexts.GetStatusContext
 
toString() - Method in class alluxio.master.file.contexts.ListStatusContext
 
toString() - Method in class alluxio.master.file.contexts.LoadMetadataContext
 
toString() - Method in class alluxio.master.file.contexts.MountContext
 
toString() - Method in class alluxio.master.file.contexts.RenameContext
 
toString() - Method in class alluxio.master.file.contexts.ScheduleAsyncPersistenceContext
 
toString() - Method in class alluxio.master.file.contexts.SetAclContext
 
toString() - Method in class alluxio.master.file.contexts.SetAttributeContext
 
toString() - Method in class alluxio.master.file.contexts.WorkerHeartbeatContext
 
toString() - Method in class alluxio.master.file.FileSystemMasterAuditContext
 
toString() - Method in class alluxio.master.file.InodeSyncStream
 
toString() - Method in class alluxio.master.file.meta.Edge
 
toString() - Method in class alluxio.master.file.meta.LockedInodePath
 
toString() - Method in class alluxio.master.file.meta.LockingScheme
 
toString() - Method in class alluxio.master.file.meta.MutableInodeDirectory
 
toString() - Method in class alluxio.master.file.meta.MutableInodeFile
 
toString() - Method in class alluxio.master.file.meta.options.MountInfo
 
toString() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
toString() - Method in class alluxio.master.file.meta.SyncCheck
 
toString() - Method in enum alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
 
toString() - Method in class alluxio.master.file.PersistJob
 
toString() - Method in class alluxio.master.job.common.CmdInfo
tostring.
toString() - Method in class alluxio.master.job.CopyJob
 
toString() - Method in class alluxio.master.job.DoraLoadJob.DoraLoadTask
 
toString() - Method in class alluxio.master.job.DoraLoadJob
 
toString() - Method in class alluxio.master.job.JobMasterAuditContext
 
toString() - Method in class alluxio.master.job.LoadJob
 
toString() - Method in class alluxio.master.job.MoveJob
 
toString() - Method in class alluxio.master.journal.options.JournalReaderOptions
 
toString() - Method in class alluxio.master.journal.options.JournalWriterOptions
 
toString() - Method in class alluxio.master.journal.raft.RaftJournalSystem
 
toString() - Method in class alluxio.master.journal.ufs.UfsJournal
 
toString() - Method in class alluxio.master.journal.ufs.UfsJournalFile
 
toString() - Method in class alluxio.master.meta.JobMasterInfo
 
toString() - Method in class alluxio.master.meta.MasterInfo
 
toString() - Method in class alluxio.master.meta.ProxyInfo
 
toString() - Method in class alluxio.master.metrics.MetricsStore.ClusterCounterKey
 
toString() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
toString() - Method in class alluxio.master.predicate.interval.Interval
 
toString() - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoIdentity
 
toString() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
toString() - Method in class alluxio.master.transport.GrpcMessagingConnection
 
toString() - Method in enum alluxio.master.WorkerState
 
toString() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
toString() - Method in class alluxio.membership.AlluxioEtcdClient.Lease
 
toString() - Method in class alluxio.membership.WorkerServiceEntity
 
toString() - Method in class alluxio.metrics.Metric
 
toString() - Method in enum alluxio.metrics.MetricInfo.UfsOps
 
toString() - Method in class alluxio.metrics.MetricKey
 
toString() - Method in class alluxio.metrics.MetricsConfig
 
toString() - Method in class alluxio.metrics.MetricsFilter
 
toString() - Method in enum alluxio.metrics.MetricsSystem.InstanceType
 
toString() - Method in class alluxio.multi.process.MasterNetAddress
 
toString() - Method in class alluxio.network.protocol.RPCProtoMessage
 
toString() - Method in class alluxio.proxy.AlluxioProxyProcess
 
toString() - Method in class alluxio.proxy.s3.CompleteMultipartUploadResult
 
toString() - Method in class alluxio.proxy.s3.MultipartUploadCleaner.AbortTask
 
toString() - Method in class alluxio.s3.auth.AwsAuthInfo
 
toString() - Method in class alluxio.s3.ListBucketOptions
 
toString() - Method in class alluxio.s3.S3AuditContext
 
toString() - Method in class alluxio.s3.TaggingData
 
toString() - Method in class alluxio.scheduler.job.Task
 
toString() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
toString() - Method in class alluxio.security.authorization.AccessControlList
 
toString() - Method in class alluxio.security.authorization.AclActions
 
toString() - Method in class alluxio.security.authorization.AclEntry
 
toString() - Method in enum alluxio.security.authorization.Mode.Bits
 
toString() - Method in class alluxio.security.authorization.Mode
 
toString() - Method in class alluxio.security.CurrentUser
 
toString() - Method in class alluxio.security.User
 
toString() - Method in class alluxio.SessionInfo
 
toString() - Method in class alluxio.shell.ShellCommand
Converts the command to string repr.
toString() - Method in enum alluxio.stress.client.ClientIOOperation
 
toString() - Method in enum alluxio.stress.common.FileSystemClientType
 
toString() - Method in class alluxio.stress.job.StressBenchConfig
 
toString() - Method in class alluxio.stress.worker.IOTaskResult.Point
 
toString() - Method in class alluxio.stress.worker.IOTaskResult
 
toString() - Method in class alluxio.stress.worker.IOTaskSummary.SpeedStat
 
toString() - Method in class alluxio.stress.worker.IOTaskSummary
 
toString() - Method in class alluxio.underfs.AbstractUfsManager.Key
 
toString() - Method in class alluxio.underfs.options.CreateOptions
 
toString() - Method in class alluxio.underfs.options.DeleteOptions
 
toString() - Method in class alluxio.underfs.options.FileLocationOptions
 
toString() - Method in class alluxio.underfs.options.ListOptions
 
toString() - Method in class alluxio.underfs.options.MkdirsOptions
 
toString() - Method in class alluxio.underfs.options.OpenOptions
 
toString() - Method in class alluxio.underfs.UfsDirectoryStatus
 
toString() - Method in class alluxio.underfs.UfsFileStatus
 
toString() - Method in class alluxio.underfs.UnderFileSystemWithLogging.UfsCallable
 
toString() - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
toString() - Method in class alluxio.uri.MultiMasterAuthority
 
toString() - Method in class alluxio.uri.NoAuthority
 
toString() - Method in class alluxio.uri.SingleMasterAuthority
 
toString() - Method in class alluxio.uri.UnknownAuthority
 
toString() - Method in class alluxio.uri.ZookeeperAuthority
 
toString() - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
toString() - Method in class alluxio.util.executor.ControllableQueue
 
toString() - Method in class alluxio.util.proto.ProtoMessage
 
toString() - Method in exception alluxio.util.ShellUtils.ExitCodeException
 
toString() - Method in class alluxio.util.UnixMountInfo.Options
 
toString() - Method in class alluxio.util.UnixMountInfo
 
toString() - Method in class alluxio.util.WaitForOptions
 
toString() - Method in class alluxio.wire.Address
 
toString() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
toString() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
toString() - Method in class alluxio.wire.AlluxioMasterInfo
 
toString() - Method in class alluxio.wire.AlluxioProxyInfo
 
toString() - Method in class alluxio.wire.AlluxioWorkerInfo
 
toString() - Method in class alluxio.wire.BackupStatus
 
toString() - Method in class alluxio.wire.BlockInfo
 
toString() - Method in class alluxio.wire.BlockLocation
 
toString() - Method in class alluxio.wire.BlockMasterInfo
 
toString() - Method in class alluxio.wire.BlockReadRequest
 
toString() - Method in class alluxio.wire.Capacity
 
toString() - Method in class alluxio.wire.FileBlockInfo
 
toString() - Method in class alluxio.wire.FileInfo
 
toString() - Method in class alluxio.wire.InconsistentProperty
 
toString() - Method in class alluxio.wire.JournalDiskInfo
 
toString() - Method in class alluxio.wire.LogInfo
 
toString() - Method in class alluxio.wire.MasterInfo
 
toString() - Method in class alluxio.wire.MasterWebUIBrowse
 
toString() - Method in class alluxio.wire.MasterWebUIConfiguration
 
toString() - Method in class alluxio.wire.MasterWebUIData
 
toString() - Method in class alluxio.wire.MasterWebUIInit
 
toString() - Method in class alluxio.wire.MasterWebUILogs
 
toString() - Method in class alluxio.wire.MasterWebUIMasters
 
toString() - Method in class alluxio.wire.MasterWebUIMetrics
 
toString() - Method in class alluxio.wire.MasterWebUIMountTable
 
toString() - Method in class alluxio.wire.MasterWebUIOverview
 
toString() - Method in class alluxio.wire.MasterWebUIWorkers
 
toString() - Method in class alluxio.wire.MountPointInfo
 
toString() - Method in class alluxio.wire.RegisterLease
 
toString() - Method in class alluxio.wire.WorkerIdentity
 
toString() - Method in class alluxio.wire.WorkerInfo
 
toString() - Method in class alluxio.wire.WorkerNetAddress
 
toString() - Method in class alluxio.wire.WorkerWebUIBlockInfo
 
toString() - Method in class alluxio.wire.WorkerWebUIConfiguration
 
toString() - Method in class alluxio.wire.WorkerWebUIInit
 
toString() - Method in class alluxio.wire.WorkerWebUILogs
 
toString() - Method in class alluxio.wire.WorkerWebUIMetrics
 
toString() - Method in class alluxio.wire.WorkerWebUIOperations
 
toString() - Method in class alluxio.wire.WorkerWebUIOverview
 
toString() - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
toString() - Method in class alluxio.worker.AlluxioWorkerProcess
 
toString() - Method in class alluxio.worker.block.AllocateOptions
 
toString() - Method in class alluxio.worker.block.BlockStoreLocation
Converts the location to a human readable form.
toString() - Method in class alluxio.worker.block.CreateBlockOptions
 
toString() - Method in class alluxio.worker.block.io.BlockClient
 
toString() - Method in class alluxio.worker.grpc.WriteRequest
 
toStringArray(ArrayList<String>) - Static method in class alluxio.util.CommonUtils
Parses ArrayList<String> into String[].
toStringEntries() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
toStringEntries() - Method in class alluxio.security.authorization.AccessControlList
 
toStringHadoopFileSplit(FileSplit) - Static method in class alluxio.hadoop.HadoopUtils
Returns a string representation of a Hadoop FileSplit.
toStringHadoopFileStatus(FileStatus) - Static method in class alluxio.hadoop.HadoopUtils
Returns a string representation of a Hadoop FileStatus.
toStringHelper() - Method in class alluxio.master.file.meta.MutableInode
 
toStringHelper() - Method in class alluxio.underfs.UfsStatus
 
toStringHelper() - Method in class alluxio.worker.grpc.UfsFileWriteRequest
 
toStringHelper() - Method in class alluxio.worker.grpc.WriteRequest
 
toSyncChildren() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
TOTAL_EXTRA_TIME - Static variable in class alluxio.metrics.MetricKey.Name
 
TOTAL_EXTRA_TIME - Static variable in class alluxio.metrics.MetricKey
 
TOTALBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
touch(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Creates an empty file.
TouchCommand - Class in alluxio.cli.fs.command
Creates a 0 byte file specified by argv.
TouchCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.TouchCommand
 
toUfsInfo() - Method in class alluxio.master.file.meta.options.MountInfo
 
toUpdateMetaData() - Method in class alluxio.master.file.meta.UfsSyncUtils.SyncPlan
 
toUserPropertyMap(ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
toUUID(WorkerIdentity) - Method in class alluxio.wire.WorkerIdentity.ParserV1
Converts to a UUID.
trace(String) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
transfer(ReadableByteChannel, WritableByteChannel) - Static method in class alluxio.util.io.BufferUtils
An efficient copy between two channels with a fixed-size buffer.
TRANSFER_FAILED - Static variable in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
TRANSFER_INIT - Static variable in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
TRANSFER_SUCCESS - Static variable in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
TRANSFERID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
TRANSFERID_FIELD_NUMBER - Static variable in class alluxio.grpc.TransferLeadershipPResponse
 
TransferLeaderMessage - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.TransferLeaderMessage
TransferLeaderMessage.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.TransferLeaderMessage
TransferLeaderMessageOrBuilder - Interface in alluxio.grpc
 
transferLeadership(NetAddress) - Method in interface alluxio.client.journal.JournalMasterClient
Initiates changing the leading master of the quorum.
transferLeadership(NetAddress) - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
transferLeadership(TransferLeadershipPRequest, StreamObserver<TransferLeadershipPResponse>) - Method in interface alluxio.grpc.JournalMasterClientServiceGrpc.AsyncService
Transfers the leadership from the current leader to another designated leader.
transferLeadership(TransferLeadershipPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceBlockingStub
Transfers the leadership from the current leader to another designated leader.
transferLeadership(TransferLeadershipPRequest) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceFutureStub
Transfers the leadership from the current leader to another designated leader.
transferLeadership(TransferLeadershipPRequest, StreamObserver<TransferLeadershipPResponse>) - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceStub
Transfers the leadership from the current leader to another designated leader.
transferLeadership(NetAddress) - Method in class alluxio.master.journal.DefaultJournalMaster
 
transferLeadership(NetAddress) - Method in interface alluxio.master.journal.JournalMaster
Changes the leading master of the journal quorum.
transferLeadership(TransferLeadershipPRequest, StreamObserver<TransferLeadershipPResponse>) - Method in class alluxio.master.journal.JournalMasterClientServiceHandler
 
transferLeadership(NetAddress) - Method in class alluxio.master.journal.raft.RaftJournalSystem
Transfers the leadership of the quorum to another server.
TransferLeadershipPOptions - Class in alluxio.grpc
TransferLeadership API
TransferLeadershipPOptions.Builder - Class in alluxio.grpc
TransferLeadership API
TransferLeadershipPOptionsOrBuilder - Interface in alluxio.grpc
 
TransferLeadershipPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.TransferLeadershipPRequest
TransferLeadershipPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.TransferLeadershipPRequest
TransferLeadershipPRequestOrBuilder - Interface in alluxio.grpc
 
TransferLeadershipPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.TransferLeadershipPResponse
TransferLeadershipPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.journal.TransferLeadershipPResponse
TransferLeadershipPResponseOrBuilder - Interface in alluxio.grpc
 
transferTo(ByteBuf) - Method in class alluxio.worker.block.io.BlockReader
Transfers data (up to buf.writableBytes()) from this reader to the buffer.
transferTo(ByteBuf) - Method in class alluxio.worker.dora.PagedFileReader
 
Transformation - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Transformation
Transformation.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Transformation
TransformationOrBuilder - Interface in alluxio.grpc.table
 
TRANSFORMATIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Partition
 
TransformJobInfo - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformJobInfo
TransformJobInfo.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformJobInfo
TransformJobInfoOrBuilder - Interface in alluxio.grpc.table
 
transformTable(String, String, String) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
transformTable(String, String, String) - Method in interface alluxio.client.table.TableMasterClient
Transforms a table.
transformTable(TransformTablePRequest, StreamObserver<TransformTablePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
 
transformTable(TransformTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
 
transformTable(TransformTablePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
 
transformTable(TransformTablePRequest, StreamObserver<TransformTablePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
 
TransformTablePRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformTablePRequest
TransformTablePRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformTablePRequest
TransformTablePRequestOrBuilder - Interface in alluxio.grpc.table
 
TransformTablePResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformTablePResponse
TransformTablePResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.TransformTablePResponse
TransformTablePResponseOrBuilder - Interface in alluxio.grpc.table
 
transition(T, S, S) - Method in class alluxio.client.file.dora.netty.DebugLoggingTracer
 
Transitioning_VALUE - Static variable in enum alluxio.grpc.BackupState
Transitioning = 3;
translateBucketAcl(GSAccessControlList, String) - Static method in class alluxio.underfs.gcs.GCSUtils
Translates GCS bucket owner ACL to Alluxio owner mode.
translateBucketAcl(AccessControlList, String) - Static method in class alluxio.underfs.s3a.S3AUtils
Translates S3 bucket ACL to Alluxio owner mode.
translateModeToPosixPermissions(int) - Static method in class alluxio.util.io.FileUtils
Translate mode to posix file permissions.
translatePosixPermissionToMode(Set<PosixFilePermission>) - Static method in class alluxio.util.io.FileUtils
Translate posix file permissions to short mode.
TRANSMSG_FIELD_NUMBER - Static variable in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
TransportMessage - Class in alluxio.grpc
Protobuf type alluxio.grpc.messaging.TransportMessage
TransportMessage.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.messaging.TransportMessage
TransportMessageOrBuilder - Interface in alluxio.grpc
 
traverse() - Method in class alluxio.master.file.meta.LockedInodePath
Traverses the inode path according to its lock pattern.
trialSetup() - Method in class alluxio.invalidation.cache.InvalidationSyncCacheBench.ThreadState
 
trigger(T) - Method in class alluxio.client.file.dora.netty.DebugLoggingTracer
 
TRIGGERED_EMBEDDED_CHECKPOINT - Static variable in class alluxio.multi.process.PortCoordination
 
TRIGGERED_UFS_CHECKPOINT - Static variable in class alluxio.multi.process.PortCoordination
 
TriggerEventsWithParam(StateMachineConfig<NettyDataReaderStateMachine.State, NettyDataReaderStateMachine.TriggerEvent>) - Constructor for class alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEventsWithParam
Trigger event with parameters for @{NettyClientStateMacine}.
triggerPolicy(TriggerPolicyRequest, StreamObserver<TriggerPolicyResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
Trigger policy scan for all policies
triggerPolicy(TriggerPolicyRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
Trigger policy scan for all policies
triggerPolicy(TriggerPolicyRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
Trigger policy scan for all policies
triggerPolicy(TriggerPolicyRequest, StreamObserver<TriggerPolicyResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
Trigger policy scan for all policies
TriggerPolicyRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.TriggerPolicyRequest
TriggerPolicyRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.TriggerPolicyRequest
TriggerPolicyRequestOrBuilder - Interface in alluxio.grpc
 
TriggerPolicyResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.TriggerPolicyResponse
TriggerPolicyResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.TriggerPolicyResponse
TriggerPolicyResponseOrBuilder - Interface in alluxio.grpc
 
truncate(String, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
Since files can be written only once, only sequentially, and never be modified in Alluxio, truncate is not supported internally by Alluxio.
truncate(long) - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
truncate(long) - Method in class alluxio.fuse.file.FuseFileInStream
 
truncate(long) - Method in class alluxio.fuse.file.FuseFileOutStream
 
truncate(long) - Method in interface alluxio.fuse.file.FuseFileStream
Truncates the file to the given size.
truncate(long) - Method in class alluxio.fuse.file.FusePositionReader
 
truncate(long) - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
truncate(String, long) - Method in interface alluxio.jnifuse.FuseFileSystem
 
TRUNCATE_VALUE - Static variable in enum alluxio.proto.journal.File.XAttrUpdateStrategy
TRUNCATE = 1;
truncateCallback(String, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
truncateMessageLineLength(Object) - Static method in class alluxio.util.LogUtils
Truncates each line of a message to a certain length.
truncateMessageLineLength(Object, int) - Static method in class alluxio.util.LogUtils
Truncates each line of a message to a certain length.
TRY_CACHE_VALUE - Static variable in enum alluxio.grpc.WritePType
Deprecated.
tryAbortMultipartUpload(FileSystem, FileSystem, String, String, String) - Method in class alluxio.proxy.s3.MultipartUploadCleaner
Try to abort a multipart upload if it was timeout.
tryAcquirePersistingLock(long) - Method in class alluxio.master.file.meta.InodeLockManager
Tries to acquire a lock for persisting the specified inode id.
tryAcquireRegisterLease(GetRegisterLeasePRequest) - Method in interface alluxio.master.block.BlockMaster
Try to acquire a RegisterLease for the worker.
tryAcquireRegisterLease(GetRegisterLeasePRequest) - Method in class alluxio.master.block.DefaultBlockMaster
 
tryComplete() - Method in class alluxio.concurrent.jsr.CountedCompleter
If the pending count is nonzero, decrements the count; otherwise invokes CountedCompleter.onCompletion(CountedCompleter) and then similarly tries to complete this task's completer, if one exists, else marks this task as complete.
tryGet(K, LockMode) - Method in class alluxio.collections.LockPool
Attempts to take a lock on the given key.
tryLoadingConfigFromMaster(FileSystemContext) - Static method in class alluxio.fuse.AlluxioFuseUtils
Tries to laod Alluxio config from Alluxio Master through Grpc.
tryLock(String, LockMode) - Method in class alluxio.fuse.lock.FuseReadWriteLockManager
Tries to lock the given poth with read/write mode.
tryLock() - Method in class alluxio.master.block.meta.WorkerMetaLock
 
tryLock(long, TimeUnit) - Method in class alluxio.master.block.meta.WorkerMetaLock
 
tryLockEdge(Edge, LockMode) - Method in class alluxio.master.file.meta.InodeLockManager
Attempts to acquire an edge lock.
tryLockInode(Long, LockMode) - Method in class alluxio.master.file.meta.InodeLockManager
Attempts to acquire an inode lock.
tryLockInodePath(LockingScheme, JournalContext) - Method in class alluxio.master.file.meta.InodeTree
Locks existing inodes on the path and with the pattern defined by LockingScheme.getPath() and LockingScheme.getPattern().
tryUnfork() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Tries to unschedule this task for execution.
TS_FIELD_NUMBER - Static variable in class alluxio.proto.meta.DoraMeta.FileStatus
 
TTL_ACTION_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
TTL_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
TTL_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemMasterCommonPOptions
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
TTL_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
TtlAction - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.TtlAction
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemMasterCommonPOptions
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
TTLACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
TtlBucket - Class in alluxio.master.file.meta
A bucket with all inodes whose ttl value lies in the bucket's time interval.
TtlBucket(long) - Constructor for class alluxio.master.file.meta.TtlBucket
Creates a new instance of TtlBucket.
TtlBucketList - Class in alluxio.master.file.meta
A list of non-empty TtlBuckets sorted by ttl interval start time of each bucket.
TtlBucketList(ReadOnlyInodeStore) - Constructor for class alluxio.master.file.meta.TtlBucketList
Creates a new list of TtlBuckets.
TWO_MIN_EXP_BACKOFF - Static variable in class alluxio.master.AlluxioMasterMonitor
 
TwoChoiceRandomEvictor - Class in alluxio.client.file.cache.evictor
Two Choice Random client-side cache eviction policy.
TwoChoiceRandomEvictor(CacheEvictorOptions) - Constructor for class alluxio.client.file.cache.evictor.TwoChoiceRandomEvictor
Constructor.
TwoKeyConcurrentMap<K1,K2,V,M extends Map<K2,V>> - Class in alluxio.collections
A two-level concurrent map implementation.
TwoKeyConcurrentMap(Supplier<M>) - Constructor for class alluxio.collections.TwoKeyConcurrentMap
 
TwoKeyConcurrentMap.TriFunction<A,B,C,R> - Interface in alluxio.collections
A function with three arguments.
TwoKeyConcurrentSortedMap<K1,K2,V,M extends SortedMap<K2,V>> - Class in alluxio.collections
A two-level concurrent map implementation where the inner map is sorted.
TwoKeyConcurrentSortedMap(Supplier<M>) - Constructor for class alluxio.collections.TwoKeyConcurrentSortedMap
 
TX_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
TYPE - Static variable in class alluxio.master.job.CopyJob
 
TYPE - Static variable in class alluxio.master.job.DoraLoadJob
 
TYPE - Static variable in class alluxio.master.job.LoadJob
 
TYPE - Static variable in class alluxio.master.job.MoveJob
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobDescription
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.PAclEntry
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.FieldSchema
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteRequestCommand
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadResponse
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.WriteRequest
 
TYPE_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AclEntry
 

U

UDB_CONNECTION_URI_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
UDB_DB_NAME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
UDB_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AttachDatabasePRequest
 
UFS_CONFIG - Static variable in class alluxio.cli.ValidationConfig
 
UFS_COSN_VERSION - Static variable in class alluxio.CosnUfsConstants
 
UFS_FILE_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
UFS_FILE_VALUE - Static variable in enum alluxio.grpc.RequestType
UFS_FILE = 1;
UFS_FILE_VALUE - Static variable in enum alluxio.proto.dataserver.Protocol.RequestType
UFS_FILE = 1;
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAttributeEntry
 
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
UFS_FINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
UFS_FULL_PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
UFS_HADOOP_VERSION - Static variable in class alluxio.UfsConstants
 
UFS_INPUT_STREAM_CACHE_EXPIRATION - Static variable in class alluxio.Constants
 
UFS_JOURNAL_MOUNT_ID - Static variable in class alluxio.util.IdUtils
The journal ufs is stored as a special mount in the ufs manage.
UFS_OP_PREFIX - Static variable in class alluxio.metrics.MetricInfo
 
UFS_OP_SAVED_PREFIX - Static variable in class alluxio.metrics.MetricInfo
 
UFS_OPS_DESC - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
UFS_OZONE_VERSION - Static variable in class alluxio.OzoneUfsConstants
 
UFS_PATH - Static variable in class alluxio.cli.ValidationConfig
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.Block
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.File
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
UFS_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
UFS_READ_HEARTBEAT_VALUE - Static variable in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
A heatbeat message indicates that the server is still actively acquiring access to a UFS file.
UFS_READ_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyRequest
 
UFS_READ_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveRequest
 
UFS_STATUS_CACHE_CHILDREN_SIZE_TOTAL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
UFS_STATUS_CACHE_SIZE_TOTAL - Static variable in class alluxio.master.file.DefaultFileSystemMaster.Metrics
 
UFS_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileFailure
 
UFS_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadFileRequest
 
UFS_WRITER_EXECUTOR - Static variable in class alluxio.worker.netty.NettyExecutors
 
UfsAbsentPathCache - Interface in alluxio.master.file.meta
Cache for recording information about paths that are not present in UFS.
UfsAbsentPathCache.Factory - Class in alluxio.master.file.meta
Factory class for UfsAbsentPathCache.
UfsBaseFileSystem - Class in alluxio.client.file.ufs
An implementation of the FileSystem interface that directly interacts with a target UFS.
UfsBaseFileSystem(FileSystemContext, UfsFileSystemOptions) - Constructor for class alluxio.client.file.ufs.UfsBaseFileSystem
Constructs a new base file system.
UfsBaseFileSystem(FileSystemContext, UfsFileSystemOptions, UfsManager.UfsClient) - Constructor for class alluxio.client.file.ufs.UfsBaseFileSystem
Constructs a wrapper file system based on given UnderFileSystem.
UfsBlockAccessTokenUnavailableException - Exception in alluxio.exception
The exception thrown when it fails to grab a UFS access token for a UFS block.
UfsBlockAccessTokenUnavailableException(String) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified detail message.
UfsBlockAccessTokenUnavailableException(String, Throwable) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified detail message and cause.
UfsBlockAccessTokenUnavailableException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified exception message and multiple parameters.
UfsBlockAccessTokenUnavailableException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
UfsBlockLocationCache - Interface in alluxio.master.file.meta
Cache for block locations in the UFS.
UfsBlockLocationCache.Factory - Class in alluxio.master.file.meta
Factory class for UfsBlockLocationCache.
UfsCallable() - Constructor for class alluxio.underfs.UnderFileSystemWithLogging.UfsCallable
 
UFSCAPACITYBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
UfsCheckpointManager - Class in alluxio.master.journalv0.ufs
Manages the checkpoint for a journal.
UfsCheckpointManager(UnderFileSystem, URI, UfsJournalWriter) - Constructor for class alluxio.master.journalv0.ufs.UfsCheckpointManager
Creates a new instance of UfsCheckpointManager.
UfsClient(Supplier<UnderFileSystem>, AlluxioURI) - Constructor for class alluxio.underfs.UfsManager.UfsClient
 
UfsCommand - Class in alluxio.cli.fsadmin.report
Prints under filesystem information.
UfsCommand(FileSystemMasterClient) - Constructor for class alluxio.cli.fsadmin.report.UfsCommand
Creates a new instance of UfsCommand.
UfsConstants - Class in alluxio
Ufs constants from compilation time by maven.
UfsDeleter - Interface in alluxio.master.file
Interface for deleting persisted entries from the UFS.
UfsDirectoryStatus - Class in alluxio.underfs
Information about a directory in the under file system.
UfsDirectoryStatus(String, String, String, short, Long, Map<String, byte[]>) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus.
UfsDirectoryStatus(String, String, String, short, Long) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus.
UfsDirectoryStatus(String, String, String, short) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus without providing last modified time or extended attributes.
UfsDirectoryStatus(UfsDirectoryStatus) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates a new instance of under directory information as a copy.
UfsDirectoryValidationTask - Class in alluxio.cli
Task for validating whether UFS directory is accessible.
UfsDirectoryValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.UfsDirectoryValidationTask
Creates a new instance of UfsDirectoryValidationTask for validating root under file system.
UfsFileInStream - Class in alluxio.client.file.ufs
Supports reading from a ufs file directly.
UfsFileInStream(Function<Long, InputStream>, long) - Constructor for class alluxio.client.file.ufs.UfsFileInStream
Creates a new UfsFileInStream.
UfsFileIterable - Class in alluxio.master.job
Iterable for FileInfo objects.
UfsFileIterable(UnderFileSystem, String, Optional<String>, Predicate<FileInfo>) - Constructor for class alluxio.master.job.UfsFileIterable
Creates a new instance of FileIterable.
UfsFileOutStream - Class in alluxio.client.file.ufs
Supports writing to a UFS file directly.
UfsFileOutStream(OutputStream) - Constructor for class alluxio.client.file.ufs.UfsFileOutStream
Creates a UfsFileOutStream.
UfsFilePacketWriter(UfsFileWriteRequestContext, Channel, UfsManager) - Constructor for class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
UfsFileStatus - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.UfsFileStatus
UfsFileStatus - Class in alluxio.underfs
Information about a file in UnderFileSystem.
UfsFileStatus(String, String, long, Long, String, String, short, Map<String, byte[]>, long) - Constructor for class alluxio.underfs.UfsFileStatus
Creates new instance of UfsFileStatus.
UfsFileStatus(String, String, long, Long, String, String, short, long) - Constructor for class alluxio.underfs.UfsFileStatus
Creates new instance of UfsFileStatus without any extended attributes.
UfsFileStatus(String, String, long, Long, String, String, short, Map<String, byte[]>) - Constructor for class alluxio.underfs.UfsFileStatus
Deprecated.
as of 2.1.0, use #UfsFileStatus(String, String, long, long, String, String, short, Map, long)
UfsFileStatus(String, String, long, Long, String, String, short) - Constructor for class alluxio.underfs.UfsFileStatus
Deprecated.
as of 2.1.0, use #UfsFileStatus(String, String, long, long, String, String, short, long).
UfsFileStatus(UfsFileStatus) - Constructor for class alluxio.underfs.UfsFileStatus
Creates a new instance of UfsFileStatus as a copy.
UfsFileStatus.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.UfsFileStatus
UfsFileStatusOrBuilder - Interface in alluxio.grpc
 
UfsFileSystemOptions - Class in alluxio.client.file.options
Options for creating the UfsBaseFileSystem.
UfsFileSystemOptions(String) - Constructor for class alluxio.client.file.options.UfsFileSystemOptions
Creates a new instance of UfsFileSystemOptions.
UfsFileWriteHandler - Class in alluxio.worker.grpc
This handler handles writes to a file in the under file system.
UfsFileWriteHandler - Class in alluxio.worker.netty
This handler handles writes to a file in the under file system.
UfsFileWriteHandler(ExecutorService, UfsManager) - Constructor for class alluxio.worker.netty.UfsFileWriteHandler
Creates an instance of UfsFileWriteHandler.
UfsFileWriteHandler.UfsFilePacketWriter - Class in alluxio.worker.netty
The packet writer that writes to UFS.
UfsFileWriteRequest - Class in alluxio.worker.grpc
The UFS File write request internal representation.
UfsFileWriteRequest - Class in alluxio.worker.netty
The UFS File write request internal representation.
UfsFileWriteRequestContext - Class in alluxio.worker.grpc
The UFS File write request internal representation.
UfsFileWriteRequestContext - Class in alluxio.worker.netty
The UFS File write request internal representation.
UFSFINGERPRINT_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
UfsInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UfsInfo
UfsInfo - Class in alluxio.wire
Class to represent a ufs info.
UfsInfo() - Constructor for class alluxio.wire.UfsInfo
Creates a new instance of UfsInfo.
UfsInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UfsInfo
UFSINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetUfsInfoPResponse
 
UfsInfoOrBuilder - Interface in alluxio.grpc
 
UfsInputStreamCache - Class in alluxio.underfs
This class implements a BlockReader to read a block directly from UFS, and optionally cache the block to the Alluxio worker if the whole block it is read.
UfsInputStreamCache() - Constructor for class alluxio.underfs.UfsInputStreamCache
Constructs a new UFS input stream cache.
UfsIOBench - Class in alluxio.stress.cli
A benchmark tool measuring the IO to UFS.
UfsIOBench() - Constructor for class alluxio.stress.cli.UfsIOBench
 
UfsIOManager - Class in alluxio.underfs
Control UFS IO.
UfsIOManager(UfsManager.UfsClient) - Constructor for class alluxio.underfs.UfsIOManager
 
UfsIOParameters - Class in alluxio.stress.worker
Parameters used in the UFS I/O throughput test.
UfsIOParameters() - Constructor for class alluxio.stress.worker.UfsIOParameters
 
UfsJournal - Class in alluxio.master.journal.ufs
Implementation of UFS-based journal.
UfsJournal(URI, Master, long, Supplier<Set<JournalSink>>) - Constructor for class alluxio.master.journal.ufs.UfsJournal
Creates a new instance of UfsJournal.
UfsJournal - Class in alluxio.master.journalv0.ufs
Implementation of UFS-based journal.
UfsJournal(URI) - Constructor for class alluxio.master.journalv0.ufs.UfsJournal
Creates a new instance of UfsJournal.
UfsJournalCheckpointThread - Class in alluxio.master.journal.ufs
This thread continually replays the journal and applies it to the master, until the master initiates the shutdown of the thread.
UfsJournalCheckpointThread(Master, UfsJournal, Supplier<Set<JournalSink>>) - Constructor for class alluxio.master.journal.ufs.UfsJournalCheckpointThread
Creates a new instance of UfsJournalCheckpointThread.
UfsJournalCheckpointThread(Master, UfsJournal, long, Supplier<Set<JournalSink>>) - Constructor for class alluxio.master.journal.ufs.UfsJournalCheckpointThread
Creates a new instance of UfsJournalCheckpointThread.
UfsJournalCheckpointThread.CatchupState - Enum in alluxio.master.journal.ufs
The state of the journal catchup.
UfsJournalDumper - Class in alluxio.master.journal.tool
Implementation of AbstractJournalDumper for UFS journals.
UfsJournalDumper(String, long, long, String, String) - Constructor for class alluxio.master.journal.tool.UfsJournalDumper
Creates UFS journal dumper.
UfsJournalFile - Class in alluxio.master.journal.ufs
A simple data structure that represents a journal file.
UfsJournalFileParser - Class in alluxio.master.journal.ufs
Implementation of JournalFileParser that parses a journal file.
UfsJournalFileParser(URI) - Constructor for class alluxio.master.journal.ufs.UfsJournalFileParser
Creates a new instance of UfsJournalFileParser.
UfsJournalLogWriter - Class in alluxio.master.journal.ufs
Class for writing journal edit log entries from the primary master.
UfsJournalLogWriter(UfsJournal, long) - Constructor for class alluxio.master.journal.ufs.UfsJournalLogWriter
Creates a new instance of UfsJournalLogWriter.
UfsJournalMultiMasterPrimarySelector - Class in alluxio.master.journal.ufs
Masters use this client to elect a leader.
UfsJournalMultiMasterPrimarySelector(String, String, String) - Constructor for class alluxio.master.journal.ufs.UfsJournalMultiMasterPrimarySelector
UfsJournalProgressLogger - Class in alluxio.master.journal.ufs
Journal replay logger for the UfsJournal.
UfsJournalProgressLogger(UfsJournal, OptionalLong, Supplier<Long>) - Constructor for class alluxio.master.journal.ufs.UfsJournalProgressLogger
Creates a new instance of the journal replay progress logger.
UfsJournalReader - Class in alluxio.master.journal.ufs
Implementation of JournalReader that reads journal entries from a UFS.
UfsJournalReader(UfsJournal, boolean) - Constructor for class alluxio.master.journal.ufs.UfsJournalReader
Creates a new instance of UfsJournalReader.
UfsJournalReader(UfsJournal, long, boolean) - Constructor for class alluxio.master.journal.ufs.UfsJournalReader
Creates a new instance of UfsJournalReader.
UfsJournalReader - Class in alluxio.master.journalv0.ufs
Implementation of JournalReader based on UFS.
UfsJournalSingleMasterPrimarySelector - Class in alluxio.master.journal.ufs
Primary selector when using a single master deployment with UFS journal.
UfsJournalSingleMasterPrimarySelector() - Constructor for class alluxio.master.journal.ufs.UfsJournalSingleMasterPrimarySelector
 
UfsJournalSnapshot - Class in alluxio.master.journal.ufs
This class provides a snapshot of everything in the journal and some utility methods.
UfsJournalSystem - Class in alluxio.master.journal.ufs
Factory for under file storage journals.
UfsJournalSystem(URI, long) - Constructor for class alluxio.master.journal.ufs.UfsJournalSystem
Creates a UFS journal system with the specified base location.
UfsJournalWriter - Class in alluxio.master.journalv0.ufs
Implementation of JournalWriter based on UFS.
UfsJournalWriter.EntryOutputStream - Class in alluxio.master.journalv0.ufs
This is the output stream for the journal entries after the checkpoint.
UFSLENGTH_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePOptions
 
UfsLoadResult - Class in alluxio.underfs
The UfsLoadResult represents the result of a load operation on an Under File System (UFS).
UfsLoadResult(Stream<UfsStatus>, int, String, AlluxioURI, boolean, boolean, boolean) - Constructor for class alluxio.underfs.UfsLoadResult
Constructs a new instance of UfsLoadResult.
UFSLOCATIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileBlockInfo
 
UfsManager - Interface in alluxio.underfs
A class that manages the UFS used by different services.
UfsManager.UfsClient - Class in alluxio.underfs
Container for a UFS and the URI for that UFS.
UfsMode - Enum in alluxio.underfs
Operation mode for under storage.
UFSMODE_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateUfsModePOptions
 
UFSMODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
UfsMutableJournal - Class in alluxio.master.journalv0.ufs
Implementation of MutableJournal based on UFS.
UfsMutableJournal(URI) - Constructor for class alluxio.master.journalv0.ufs.UfsMutableJournal
 
UFSPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
UFSPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPRequest
 
UFSPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateUfsModePRequest
 
UFSPATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
UfsPMode - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.UfsPMode
UfsReadHeartBeatResponseEvent - Class in alluxio.client.file.dora.netty.event
UFS Read Heartbeat Response Event.
UfsReadHeartBeatResponseEvent() - Constructor for class alluxio.client.file.dora.netty.event.UfsReadHeartBeatResponseEvent
 
UfsReadOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.UfsReadOptions
UfsReadOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.UfsReadOptions
UfsReadOptionsOrBuilder - Interface in alluxio.grpc
 
UFSREADWORKERLOCATION_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
 
UfsStatus - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.UfsStatus
UfsStatus - Class in alluxio.underfs
Information about a file or a directory in the under file system.
UfsStatus(String, boolean, String, String, short, Long, Map<String, byte[]>) - Constructor for class alluxio.underfs.UfsStatus
Creates new instance of UfsStatus.
UfsStatus(UfsStatus) - Constructor for class alluxio.underfs.UfsStatus
Creates a new instance of UfsStatus as a copy.
UfsStatus.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.UfsStatus
UfsStatusCache - Class in alluxio.underfs
This class is a cache from an Alluxio namespace URI (AlluxioURI, i.e.
UfsStatusCache(ExecutorService, UfsAbsentPathCache, long) - Constructor for class alluxio.underfs.UfsStatusCache
Create a new instance of UfsStatusCache.
UfsStatusIterator(String, boolean, ObjectUnderFileSystem.ObjectListingChunk) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.UfsStatusIterator
Creates the iterator.
UfsStatusOrBuilder - Interface in alluxio.grpc
 
UFSSTRINGLOCATIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileBlockInfo
 
UfsSuperUserValidationTask - Class in alluxio.cli
Task for validating whether Alluxio can access UFS as super user.
UfsSuperUserValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.UfsSuperUserValidationTask
Creates a new instance of UfsSuperUserValidationTask for validating the under file system.
UfsSyncChecker - Class in alluxio.master.file
Class to check if the contents of the under storage is in-sync with the master.
UfsSyncChecker(MountTable, ReadOnlyInodeStore) - Constructor for class alluxio.master.file.UfsSyncChecker
Create a new instance of UfsSyncChecker.
UfsSyncPathCache - Class in alluxio.master.file.meta
A cache of paths that have been synchronized or have been marked as not being synchronized with the UFS.
UfsSyncPathCache(Clock) - Constructor for class alluxio.master.file.meta.UfsSyncPathCache
Creates a new instance of UfsSyncPathCache.
UfsSyncUtils - Class in alluxio.master.file.meta
Util methods for UFS sync.
UfsSyncUtils.SyncPlan - Class in alluxio.master.file.meta
A class describing how to sync an inode with the ufs.
UFSTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
UFSTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
UFSURI_FIELD_NUMBER - Static variable in class alluxio.grpc.GetMountIdPRequest
 
UFSURI_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
UFSURI_FIELD_NUMBER - Static variable in class alluxio.grpc.ReverseResolvePRequest
 
UFSUSEDBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPointInfo
 
UfsVersionValidationTask - Class in alluxio.cli
This validates the UFS configuration for a users configured UFS path.
UfsVersionValidationTask(String, AlluxioConfiguration) - Constructor for class alluxio.cli.UfsVersionValidationTask
Create a new instance of UfsVersionValidationTask.
UIFileBlockInfo - Class in alluxio.util.webui
Contains information for displaying a file block in the UI.
UIFileBlockInfo(FileBlockInfo, AlluxioConfiguration) - Constructor for class alluxio.util.webui.UIFileBlockInfo
Creates a new instance of UIFileBlockInfo.
UIFileBlockInfo(long, long, long, String, AlluxioConfiguration) - Constructor for class alluxio.util.webui.UIFileBlockInfo
Creates a new instance of UIFileBlockInfo.
UIFileInfo - Class in alluxio.util.webui
Contains information about a file to be displayed in the UI.
UIFileInfo(URIStatus, AlluxioConfiguration, List<String>) - Constructor for class alluxio.util.webui.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo(FileInfo, AlluxioConfiguration, List<String>) - Constructor for class alluxio.util.webui.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo(UIFileInfo.LocalFileInfo, AlluxioConfiguration, List<String>) - Constructor for class alluxio.util.webui.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo.LocalFileInfo - Class in alluxio.util.webui
The type Local file info.
UIMasterInfo - Class in alluxio.util.webui
Displays information about a master in the UI.
UIMasterInfo(String, long, long) - Constructor for class alluxio.util.webui.UIMasterInfo
Creates a new instance of UIMasterInfo.
UIMountPointInfo - Class in alluxio.util.webui
Contains information about a mount point to be displayed in the UI.
UIMountPointInfo(String, MountPointInfo) - Constructor for class alluxio.util.webui.UIMountPointInfo
Instantiates a new instance of UIMountPointInfo.
UIStorageDir - Class in alluxio.util.webui
Displays information about a storage directory in the UI.
UIStorageDir(String, String, long, long) - Constructor for class alluxio.util.webui.UIStorageDir
Creates a new instance of UIStorageDir.
UIUsageOnTier - Class in alluxio.util.webui
A wrapper class of the usage info per tier for displaying in the UI.
UIUsageOnTier(String, long, long) - Constructor for class alluxio.util.webui.UIUsageOnTier
Creates a new instance of UIUsageOnTier.
UIWorkerInfo - Class in alluxio.util.webui
Displays information about a worker in the UI.
UIWorkerInfo(String, long, String) - Constructor for class alluxio.util.webui.UIWorkerInfo
Creates a new instance of UIWorkerInfo.
umount(boolean) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
umount(boolean) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
Umount the mount point of this Fuse Filesystem.
UNAUTHENTICATED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
Unauthenticated indicates the request does not have valid authentication credentials for the operation.
UnauthenticatedException - Exception in alluxio.exception.status
Exception indicating that the request does not have valid authentication credentials for the operation.
UnauthenticatedException(String) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedException(Throwable) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedException(String, Throwable) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the request does not have valid authentication credentials for the operation.
UnauthenticatedRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.UnauthenticatedRuntimeException
Constructor.
UNAVAILABLE_VALUE - Static variable in enum alluxio.grpc.QuorumServerState
UNAVAILABLE = 2;
UNAVAILABLE_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
Unavailable indicates the service is currently unavailable.
UnavailableException - Exception in alluxio.exception.status
Exception indicating that the service is currently unavailable.
UnavailableException(String) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableException(Throwable) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableException(String, Throwable) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the service is currently unavailable.
UnavailableRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.UnavailableRuntimeException
Constructor.
UnavailableRuntimeException(String) - Constructor for exception alluxio.exception.runtime.UnavailableRuntimeException
Constructor.
unbuffer() - Method in interface alluxio.client.CanUnbuffer
Reduce the buffering.
unbuffer() - Method in class alluxio.client.file.cache.LocalCacheFileInStream
 
unbuffer() - Method in class alluxio.client.file.FileInStream
 
unbuffer() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
UNCHECKED_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
 
UNDEFINED_MS - Static variable in class alluxio.master.predicate.interval.Interval
The undefined ms value for start or end.
UNDEFINED_START_MS - Static variable in class alluxio.stress.BaseParameters
 
UnderFileSystem - Interface in alluxio.underfs
Alluxio stores data into an under layer file system.
UnderFileSystem.Factory - Class in alluxio.underfs
The factory for the UnderFileSystem.
UnderFileSystem.SpaceType - Enum in alluxio.underfs
The different types of space indicate the total space, the free space and the space used in the under file system.
UnderFileSystemCommonOperations - Class in alluxio.cli
Examples for under filesystem common operations.
UnderFileSystemCommonOperations(String, String, UnderFileSystem, InstancedConfiguration) - Constructor for class alluxio.cli.UnderFileSystemCommonOperations
 
UnderFileSystemConfiguration - Class in alluxio.underfs
Ufs configuration properties, including ufs specific configuration and global configuration.
UnderFileSystemConfiguration(AlluxioConfiguration, boolean) - Constructor for class alluxio.underfs.UnderFileSystemConfiguration
Constructs a new instance of UnderFileSystemConfiguration with the given properties.
UnderFileSystemContractTest - Class in alluxio.cli
Integration tests for Alluxio under filesystems.
UnderFileSystemContractTest() - Constructor for class alluxio.cli.UnderFileSystemContractTest
A constructor from default.
UnderFileSystemFactory - Interface in alluxio.underfs
Interface for under file system factories.
UnderFileSystemFactoryRegistry - Class in alluxio.underfs
Central registry of available UnderFileSystemFactory instances that uses the ServiceLoader mechanism to automatically discover available factories and provides a central place for obtaining actual UnderFileSystem instances.
UnderFileSystemUtils - Class in alluxio.util
Utility functions for working with UnderFileSystem.
UnderFileSystemWithLogging - Class in alluxio.underfs
This class forwards all calls to the UnderFileSystem interface to an internal implementation.
UnderFileSystemWithLogging.UfsCallable<T> - Class in alluxio.underfs
Interface representing a callable to the under storage system which throws an IOException if an error occurs during the external communication.
UNDERFS_ALLOW_SET_OWNER_FAILURE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_ALLOW_SET_OWNER_FAILURE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_AUTH_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_ID - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_AUTH_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_KEY - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_AUTH_KEYFILE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_KEYFILE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_AUTH_KEYRING - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_KEYRING - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_CONF_OPTS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_CONF_OPTS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_LOCALIZE_READS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_LOCALIZE_READS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MDS_NAMESPACE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MDS_NAMESPACE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MON_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MON_HOST - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MOUNT_GID - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MOUNT_GID - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MOUNT_UID - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MOUNT_UID - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CHECKSUM_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CHECKSUM_TYPE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CLEANUP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CLEANUP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_COS_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_COS_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_COS_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_COS_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_COS_MULTIPART_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_COS_MULTIPART_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_NUM - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_NUM - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_DELAY_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_DELAY_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_INITIAL_DELAY_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_INITIAL_DELAY_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_JITTER - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_JITTER - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_MAX_DELAY_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_MAX_DELAY_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_TOTAL_DURATION_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_TOTAL_DURATION_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_VERSION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_CONFIGURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_CONFIGURATION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_IMPL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_IMPL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_PREFIXES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_PREFIXES - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_REMOTE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_REMOTE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_TRASH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_TRASH_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_IO_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_IO_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_LOCAL_SKIP_BROKEN_SYMLINKS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_LOCAL_SKIP_BROKEN_SYMLINKS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_BREADCRUMBS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_BREADCRUMBS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_MULTI_RANGE_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MULTI_RANGE_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_MULTIPART_UPLOAD_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MULTIPART_UPLOAD_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_SKIP_PARENT_DIRECTORY_CREATION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_SKIP_PARENT_DIRECTORY_CREATION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_STREAMING_UPLOAD_PART_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_STREAMING_UPLOAD_PART_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_MULTIPART_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_MULTIPART_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_CONNECT_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_ECS_RAM_ROLE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_ECS_RAM_ROLE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_MULTIPART_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_MULTIPART_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_PROTOCOL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_PROTOCOL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_PROXY_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_PROXY_PORT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STS_ECS_METADATA_SERVICE_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STS_ECS_METADATA_SERVICE_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STS_TOKEN_REFRESH_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STS_TOKEN_REFRESH_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OZONE_PREFIXES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OZONE_PREFIXES - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_PERSISTENCE_ASYNC_TEMP_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_PERSISTENCE_ASYNC_TEMP_DIR - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_ADMIN_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_ADMIN_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_BULK_DELETE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_BULK_DELETE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_DISABLE_DNS_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_DISABLE_DNS_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_ENDPOINT_REGION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_ENDPOINT_REGION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_INHERIT_ACL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_INHERIT_ACL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_LIST_OBJECTS_V1 - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_LIST_OBJECTS_V1 - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_MAX_ERROR_RETRY - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_MAX_ERROR_RETRY - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_MULTIPART_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_MULTIPART_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_PROXY_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_PROXY_PORT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_REGION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_REGION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SECURE_HTTP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SECURE_HTTP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SERVER_SIDE_ENCRYPTION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SERVER_SIDE_ENCRYPTION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SIGNER_ALGORITHM - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SIGNER_ALGORITHM - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_UPLOAD_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_UPLOAD_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_STRICT_VERSION_MATCH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_STRICT_VERSION_MATCH_ENABLED - Static variable in class alluxio.conf.PropertyKey
UFS related properties.
UNDERFS_VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_VERSION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_HEADER_LAST_MODIFIED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_HEADER_LAST_MODIFIED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_PARENT_NAMES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_TITLES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERSCORE - Static variable in class alluxio.underfs.Fingerprint
 
UnderStorageType - Enum in alluxio.client
Specifies the type of data interaction with Alluxio's Under Storage.
unescape(String) - Static method in class alluxio.metrics.MetricsSystem
Unescapes a URI, reverts it to before the escape, to display it correctly.
UnevictableCacheEvictor - Class in alluxio.client.file.cache.evictor
A client-side cache eviction policy that evicts nothing for debugging purposes.
UnevictableCacheEvictor(CacheEvictorOptions) - Constructor for class alluxio.client.file.cache.evictor.UnevictableCacheEvictor
Required constructor.
UnexpectedAlluxioException - Exception in alluxio.exception
The exception thrown when an unexpected error occurs within the Alluxio system.
UnexpectedAlluxioException(String) - Constructor for exception alluxio.exception.UnexpectedAlluxioException
Constructs a new exception with the specified detail message.
unfinishedTasks() - Method in class alluxio.worker.job.task.TaskExecutorManager
 
UNFINISHEDTASKS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
uniformTimer(String) - Static method in class alluxio.metrics.MetricsSystem
Same with MetricsSystem.timer(java.lang.String) but with UniformReservoir for sampling.
UNIMPLEMENTED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
Unimplemented indicates operation is not implemented or not supported/enabled in this service.
UnimplementedException - Exception in alluxio.exception.status
Exception indicating that an operation is not implemented or not supported/enabled in this service.
UnimplementedException(String) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedException(Throwable) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedException(String, Throwable) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that an operation is not implemented or not supported/enabled in this service.
UnimplementedRuntimeException(Throwable, ErrorType) - Constructor for exception alluxio.exception.runtime.UnimplementedRuntimeException
Constructor.
UnimplementedRuntimeException(String) - Constructor for exception alluxio.exception.runtime.UnimplementedRuntimeException
Constructor.
UninstallCommand - Class in alluxio.cli.extensions.command
Uninstall an extension.
UninstallCommand() - Constructor for class alluxio.cli.extensions.command.UninstallCommand
Constructs a new instance of UninstallCommand.
UNION_PRESERVE_VALUE - Static variable in enum alluxio.proto.journal.File.XAttrUpdateStrategy
UNION_PRESERVE = 3;
UNION_REPLACE_VALUE - Static variable in enum alluxio.proto.journal.File.XAttrUpdateStrategy
UNION_REPLACE = 2;
uniqPath() - Static method in class alluxio.util.io.PathUtils
Creates a unique path based off the caller.
UniqueBlockingQueue<T> - Class in alluxio.util.executor
A blocking queue containing only unique elements, based on LinkedBlockingQueue implementation.
UniqueBlockingQueue(int) - Constructor for class alluxio.util.executor.UniqueBlockingQueue
Constructor for a UniqueBlockingQueue.
UniqueFieldIndex<T,V> - Class in alluxio.collections
A class representing a unique index.
UniqueFieldIndex(IndexDefinition<T, V>) - Constructor for class alluxio.collections.UniqueFieldIndex
Constructs a new UniqueFieldIndex instance.
UnixMountInfo - Class in alluxio.util
Class representing an entry in a Unix /etc/fstab file.
UnixMountInfo.Builder - Class in alluxio.util
Builder for UnixMountInfo.
UnixMountInfo.Options - Class in alluxio.util
Unix mount info options.
UnixMountInfo.Options.Builder - Class in alluxio.util
Builder for Unix mount info options.
UNKNOWN - Static variable in class alluxio.conf.Source
 
UNKNOWN_BLOCK_SIZE - Static variable in class alluxio.underfs.UfsFileStatus
 
UNKNOWN_INODES - Static variable in class alluxio.fuse.AlluxioJniFuseFileSystem
df command will treat -1 as an unknown value.
UNKNOWN_SEQUENCE_NUMBER - Static variable in class alluxio.master.journal.ufs.UfsJournal
This is set to Long.MAX_VALUE such that the current log can be sorted after any other completed logs.
UNKNOWN_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
UNKNOWN_SERVICE = 0;
UNKNOWN_SERVICE_VERSION - Static variable in class alluxio.Constants
 
UNKNOWN_SIZE - Static variable in class alluxio.Constants
 
Unknown_VALUE - Static variable in enum alluxio.grpc.CommandType
Unknown = 0;
UNKNOWN_VALUE - Static variable in enum alluxio.grpc.Status
UNKNOWN = 0;
UNKNOWN_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
Unknown error.
UNKNOWN_VERSION - Static variable in class alluxio.extensions.ExtensionFactoryRegistry
 
UNKNOWN_VERSION_INFO - Static variable in class alluxio.RuntimeConstants
 
UnknownAuthority - Class in alluxio.uri
An unknown authority implementation.
UnknownAuthority(String) - Constructor for class alluxio.uri.UnknownAuthority
 
UnknownException - Exception in alluxio.exception.status
Exception representing an unknown error.
UnknownException(String) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownException(Throwable) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownException(String, Throwable) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownRuntimeException - Exception in alluxio.exception.runtime
Exception representing an unknown error.
UnknownRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.UnknownRuntimeException
Constructor.
UnknownRuntimeException(String) - Constructor for exception alluxio.exception.runtime.UnknownRuntimeException
Constructor.
UNLIMITED - Static variable in class alluxio.client.quota.CacheQuota
A predefined CacheQuota instance that sets NO limit.
unlink(String) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
unlink(String) - Method in class alluxio.fuse.StackFS
 
unlink(String) - Method in interface alluxio.jnifuse.FuseFileSystem
 
unlinkCallback(String) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
unlock() - Method in class alluxio.master.block.meta.WorkerMetaLock
 
unlockBlock(long) - Method in interface alluxio.worker.block.BlockStore
Releases an acquired block lock based on a lockId (returned by BlockStore.lockBlock(long, long).
unlockBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Releases an acquired block lock based on a session id and block id.
unlockBlock(long) - Method in interface alluxio.worker.block.BlockWorker
Releases the lock with the specified lock id.
unlockBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Releases the lock with the specified session and block id.
unlockLastEdge() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
unlockLastEdge() - Method in interface alluxio.master.file.meta.InodeLockList
Unlocks the last locked edge.
unlockLastEdge() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
unlockLastInode() - Method in class alluxio.master.file.meta.CompositeInodeLockList
 
unlockLastInode() - Method in interface alluxio.master.file.meta.InodeLockList
Unlocks the last locked inode.
unlockLastInode() - Method in class alluxio.master.file.meta.SimpleInodeLockList
 
unlockRead(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Releases the read locks of two buckets if they are held.
unlockWrite(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Releases the write lock of bucket if it is held.
unlockWrite(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Releases the write locks of two buckets if they are held.
unlockWrite(int, int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Releases the write locks of three buckets if they are held.
unlockWriteSegment(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Releases the write lock of the ith segment if it is held.
UnmodifiableArrayList<T> - Class in alluxio.collections
This class provides an unmodifiable List proxy for an underlying array.
UnmodifiableArrayList(T[]) - Constructor for class alluxio.collections.UnmodifiableArrayList
 
UnmodifiedForFactory() - Constructor for class alluxio.master.predicate.TimePredicate.UnmodifiedForFactory
 
unmount(AlluxioURI, UnmountPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
unmount(AlluxioURI) - Method in interface alluxio.client.file.FileSystem
Convenience method for FileSystem.unmount(AlluxioURI, UnmountPOptions) with default options.
unmount(AlluxioURI, UnmountPOptions) - Method in interface alluxio.client.file.FileSystem
Unmounts a UFS subtree identified by the given Alluxio path.
unmount(AlluxioURI, UnmountPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
unmount(AlluxioURI) - Method in interface alluxio.client.file.FileSystemMasterClient
Unmounts the given Alluxio path.
unmount(AlluxioURI) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
unmount(AlluxioURI, UnmountPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
unmount(UnmountPRequest, StreamObserver<UnmountPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Deletes an existing "mount point", voiding the Alluxio namespace at the given path.
unmount(UnmountPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Deletes an existing "mount point", voiding the Alluxio namespace at the given path.
unmount(UnmountPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Deletes an existing "mount point", voiding the Alluxio namespace at the given path.
unmount(UnmountPRequest, StreamObserver<UnmountPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Deletes an existing "mount point", voiding the Alluxio namespace at the given path.
unmount(AlluxioURI) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
unmount(AlluxioURI) - Method in interface alluxio.master.file.FileSystemMaster
Unmounts a UFS path previously mounted onto an Alluxio path.
unmount(UnmountPRequest, StreamObserver<UnmountPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
UNMOUNT - Static variable in class alluxio.proxy.PathsRestServiceHandler
 
unmount(String, UnmountPOptions) - Method in class alluxio.proxy.PathsRestServiceHandler
 
unmountDefaults(AlluxioConfiguration) - Static method in class alluxio.util.FileSystemOptionsUtils
 
UnmountPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UnmountPOptions
UnmountPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UnmountPOptions
UnmountPOptionsOrBuilder - Interface in alluxio.grpc
 
UnmountPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UnmountPRequest
UnmountPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UnmountPRequest
UnmountPRequestOrBuilder - Interface in alluxio.grpc
 
UnmountPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UnmountPResponse
UnmountPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UnmountPResponse
UnmountPResponseOrBuilder - Interface in alluxio.grpc
 
unpause() - Method in class alluxio.master.journal.raft.JournalStateMachine
Unpause the StateMachine.
unpinBlock(BlockLock) - Method in interface alluxio.worker.block.BlockStore
Unpins an accessed block based on the id (returned by BlockStore.pinBlock(long, long)).
unregister(PropertyKey) - Static method in class alluxio.conf.PropertyKey
Unregisters the given key from the global key map.
unregister(Reconfigurable) - Static method in class alluxio.conf.ReconfigurableRegistry
remove the listener related to the given property.
unregister(T) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Unregisters an existing factory.
unregister(MetricKey) - Static method in class alluxio.metrics.MetricKey
Unregisters the given key from the global key map.
unregister(UnderFileSystemFactory) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Unregisters an existing factory.
unregisterAll() - Method in class alluxio.membership.ServiceDiscoveryRecipe
Unregister all services registered from this ServiceDiscoveryRecipe instance.
unregisterChannel(UUID) - Method in interface alluxio.security.authentication.AuthenticationServer
Unregisters given channel.
unregisterChannel(UUID) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
unregisterService(String) - Method in class alluxio.membership.ServiceDiscoveryRecipe
Unregister service and close corresponding keepalive client if any.
UnresolvablePropertyException(String) - Constructor for exception alluxio.conf.InstancedConfiguration.UnresolvablePropertyException
 
UNSCALED_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Decimal
 
unset(PropertyKey) - Static method in class alluxio.conf.Configuration
Unsets the value for the appropriate key in the Properties.
unset(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
Unsets the value for the appropriate key in the Properties.
UNSUPPORTED_VALUE - Static variable in enum alluxio.grpc.JobSource
UNSUPPORTED = 0;
UnsupportedMessageHandler - Class in alluxio.worker.netty
Netty handler which replies to the client with an unknown message error for message types which are no longer supported.
UnsupportedMessageHandler() - Constructor for class alluxio.worker.netty.UnsupportedMessageHandler
Constructs a new unsupported message handler.
unthrottle() - Method in class alluxio.worker.job.task.TaskExecutorManager
Unthrottle the TaskExecutorManager.
UNUSED0_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
UNUSED1_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
unwrap(byte[], int, int) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
unwrapResponse(Protocol.Response) - Static method in class alluxio.util.CommonUtils
unwrapResponseFrom(Protocol.Response, Channel) - Static method in class alluxio.util.CommonUtils
Unwraps a Protocol.Response associated with a channel.
UP_TIME_MS_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
UP_TIME_MS = 5;
update() - Method in interface alluxio.conf.Reconfigurable
When the property changed, this function will be invoked.
update() - Static method in class alluxio.conf.ReconfigurableRegistry
When the property was reconfigured, this function will be invoked.
update() - Method in interface alluxio.heartbeat.HeartbeatTimer
When this object needs to be reconfigured due to external configuration change etc., this function will be invoked.
update() - Method in class alluxio.heartbeat.SleepingTimer
 
update(BackupStatus) - Method in class alluxio.master.backup.BackupTracker
Replaces the internal status with given status.
update(Supplier<JournalContext>, AlluxioURI, long, MountPOptions) - Method in class alluxio.master.file.meta.MountTable
Update the mount point with new options and mount ID.
update(URI) - Method in class alluxio.master.journalv0.ufs.UfsCheckpointManager
Updates the checkpoint to the specified URI.
update(long) - Method in class alluxio.metrics.MaxReservoir
Adds a new recorded value to the reservoir.
update(UserState) - Method in interface alluxio.security.user.UserState
Use a new user state to update the credentials in the current user state.
UPDATE_CHECK_CONFIGURABLE - Static variable in class alluxio.ProjectConstants
 
UPDATE_CHECK_ENABLED - Static variable in class alluxio.ProjectConstants
 
UPDATE_CHECK_HOST - Static variable in class alluxio.ProjectConstants
 
UPDATE_CHECK_MAGIC_NUMBER - Static variable in class alluxio.ProjectConstants
 
UPDATE_INODE_DIRECTORY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
UPDATE_INODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
UPDATE_INODE_FILE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
UPDATE_UFS_MODE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
updateBackupUri(AlluxioURI) - Method in class alluxio.master.backup.BackupTracker
Updates backup URI of status.
updateBandwidth(OptionalLong) - Method in class alluxio.master.job.CopyJob
Update bandwidth.
updateBandwidth(OptionalLong) - Method in class alluxio.master.job.DoraLoadJob
Update bandwidth.
updateBandwidth(OptionalLong) - Method in class alluxio.master.job.LoadJob
Update bandwidth.
updateBandwidth(OptionalLong) - Method in class alluxio.master.job.MoveJob
Update bandwidth.
updateByModeBits(Mode.Bits) - Method in class alluxio.security.authorization.AclActions
Updates permitted actions based on the mode bits.
updateCapacityBytes(Map<String, Long>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Sets the capacity of the worker in bytes.
UpdateCheck - Class in alluxio.check
Check for updates.
updateCheckEnabled() - Method in class alluxio.fuse.options.FuseOptions
 
UpdateChecker - Class in alluxio.fuse.meta
Periodically Alluxio version update check.
UpdateChecker - Class in alluxio.master.meta
Periodically Alluxio version update check.
UpdateChecker(DefaultMetaMaster) - Constructor for class alluxio.master.meta.UpdateChecker
Creates a new instance of UpdateChecker.
updateConf(PropertyKey, Object) - Method in class alluxio.multi.process.BaseMaster
Updates the master's configuration.
updateConfiguration(Map<PropertyKey, String>) - Method in interface alluxio.client.meta.MetaMasterConfigClient
Updates properties.
updateConfiguration(Map<PropertyKey, String>) - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
updateConfiguration(UpdateConfigurationPRequest, StreamObserver<UpdateConfigurationPResponse>) - Method in interface alluxio.grpc.MetaMasterConfigurationServiceGrpc.AsyncService
 
updateConfiguration(UpdateConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceBlockingStub
 
updateConfiguration(UpdateConfigurationPRequest) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceFutureStub
 
updateConfiguration(UpdateConfigurationPRequest, StreamObserver<UpdateConfigurationPResponse>) - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceStub
 
updateConfiguration(Map<String, String>) - Method in class alluxio.master.meta.DefaultMetaMaster
 
updateConfiguration(Map<String, String>) - Method in interface alluxio.master.meta.MetaMaster
 
updateConfiguration(UpdateConfigurationPRequest, StreamObserver<UpdateConfigurationPResponse>) - Method in class alluxio.master.meta.MetaMasterConfigurationServiceHandler
 
UpdateConfigurationPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.UpdateConfigurationPRequest
UpdateConfigurationPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.UpdateConfigurationPRequest
UpdateConfigurationPRequestOrBuilder - Interface in alluxio.grpc
 
UpdateConfigurationPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.UpdateConfigurationPResponse
UpdateConfigurationPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.UpdateConfigurationPResponse
UpdateConfigurationPResponseOrBuilder - Interface in alluxio.grpc
 
updateDefaultCreateFilePOptionBuilderSupplier(Supplier<CreateFilePOptions.Builder>) - Static method in class alluxio.fuse.AlluxioFuseUtils
 
updateDeployMode(MultiProcessCluster.DeployMode) - Method in class alluxio.multi.process.MultiProcessCluster
Updates the cluster's deploy mode.
updateError(AlluxioException) - Method in class alluxio.master.backup.BackupTracker
Updates the error of backup status.
updateFromEntry(File.UpdateInodeEntry) - Method in class alluxio.master.file.meta.MutableInode
Updates this inode's state from the given entry.
updateFromEntry(File.UpdateInodeDirectoryEntry) - Method in class alluxio.master.file.meta.MutableInodeDirectory
Updates this inode directory's state from the given entry.
updateFromEntry(File.UpdateInodeFileEntry) - Method in class alluxio.master.file.meta.MutableInodeFile
Updates this inode file's state from the given entry.
updateGroup() - Method in class alluxio.master.journal.raft.RaftJournalSystem
Updates raft group with the current values from raft server.
updateHostname(String) - Method in class alluxio.master.backup.BackupTracker
Updates hostname of backup status.
updateInode(Supplier<JournalContext>, File.UpdateInodeEntry) - Method in class alluxio.master.file.meta.InodeTree
 
updateInodeAccessTimeNoJournal(long, long) - Method in class alluxio.master.file.meta.InodeTree
 
updateInodeFile(Supplier<JournalContext>, File.UpdateInodeFileEntry) - Method in class alluxio.master.file.meta.InodeTree
 
updateJob(Job<?>) - Method in class alluxio.master.scheduler.JournaledJobMetaStore
 
updateJob(Job<?>) - Method in interface alluxio.scheduler.job.JobMetaStore
Update existing job in the meta store with the new job.
UPDATELASTACCESSTIME_FIELD_NUMBER - Static variable in class alluxio.grpc.OpenFilePOptions
 
updateLastHeartbeatTimeMs() - Method in class alluxio.master.meta.ProxyInfo
Updates the last updated time of the proxy in ms.
updateLastUpdatedTimeMs() - Method in class alluxio.job.MasterWorkerInfo
Updates the last updated time of the worker in ms.
updateLastUpdatedTimeMs() - Method in class alluxio.master.block.meta.MasterWorkerInfo
Updates the last updated time of the worker in ms.
updateLastUpdatedTimeMs() - Method in class alluxio.master.meta.JobMasterInfo
Updates the last updated time of the master in ms.
updateLastUpdatedTimeMs() - Method in class alluxio.master.meta.MasterInfo
Updates the last updated time of the master in ms.
updateMask(List<AclEntry>) - Method in class alluxio.master.file.meta.MutableInode
Update Mask for the Inode.
updateMask() - Method in class alluxio.security.authorization.AccessControlList
Update the mask to be the union of owning group entry, named user entry and named group entry.
updateMask(AclActions) - Method in class alluxio.security.authorization.ExtendedACLEntries
Update the mask to be the union of owning group entry, named user entry and named group entry.
updateMasterConf(PropertyKey, String) - Method in class alluxio.multi.process.MultiProcessCluster
Updates master configuration for all masters.
updateMount(AlluxioURI, MountPOptions) - Method in class alluxio.client.file.DelegatingFileSystem
 
updateMount(AlluxioURI, MountPOptions) - Method in interface alluxio.client.file.FileSystem
Updates the options for an existing mount point.
updateMount(AlluxioURI, MountPOptions) - Method in class alluxio.client.file.FileSystemCache.InstanceCachingFileSystem
 
updateMount(AlluxioURI, MountPOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Updates options of a mount point for the given Alluxio path.
updateMount(AlluxioURI, MountPOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
updateMount(AlluxioURI, MountPOptions) - Method in class alluxio.client.file.ufs.UfsBaseFileSystem
 
updateMount(UpdateMountPRequest, StreamObserver<UpdateMountPResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Updates an existing "mount point", changing its mount properties
updateMount(UpdateMountPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Updates an existing "mount point", changing its mount properties
updateMount(UpdateMountPRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Updates an existing "mount point", changing its mount properties
updateMount(UpdateMountPRequest, StreamObserver<UpdateMountPResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Updates an existing "mount point", changing its mount properties
updateMount(AlluxioURI, MountContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
updateMount(AlluxioURI, MountContext) - Method in interface alluxio.master.file.FileSystemMaster
Update properties of an Alluxio mount point.
updateMount(UpdateMountPRequest, StreamObserver<UpdateMountPResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
UpdateMountPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateMountPRequest
UpdateMountPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateMountPRequest
UpdateMountPRequestOrBuilder - Interface in alluxio.grpc
 
UpdateMountPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateMountPResponse
UpdateMountPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateMountPResponse
UpdateMountPResponseOrBuilder - Interface in alluxio.grpc
 
updateOnDelete(PageId) - Method in interface alluxio.client.file.cache.evictor.CacheEvictor
Updates evictor after a delete operation.
updateOnDelete(PageId) - Method in class alluxio.client.file.cache.evictor.FIFOCacheEvictor
 
updateOnDelete(PageId) - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
updateOnDelete(PageId) - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
updateOnDelete(PageId) - Method in class alluxio.client.file.cache.evictor.TwoChoiceRandomEvictor
 
updateOnDelete(PageId) - Method in class alluxio.client.file.cache.evictor.UnevictableCacheEvictor
 
updateOnGet(PageId) - Method in interface alluxio.client.file.cache.evictor.CacheEvictor
Updates evictor after a get operation.
updateOnGet(PageId) - Method in class alluxio.client.file.cache.evictor.FIFOCacheEvictor
 
updateOnGet(PageId) - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
updateOnGet(PageId) - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
updateOnGet(PageId) - Method in class alluxio.client.file.cache.evictor.TwoChoiceRandomEvictor
 
updateOnGet(PageId) - Method in class alluxio.client.file.cache.evictor.UnevictableCacheEvictor
 
updateOnPut(PageId) - Method in interface alluxio.client.file.cache.evictor.CacheEvictor
Updates evictor after a put operation.
updateOnPut(PageId) - Method in class alluxio.client.file.cache.evictor.FIFOCacheEvictor
 
updateOnPut(PageId) - Method in class alluxio.client.file.cache.evictor.LFUCacheEvictor
 
updateOnPut(PageId) - Method in class alluxio.client.file.cache.evictor.LRUCacheEvictor
 
updateOnPut(PageId) - Method in class alluxio.client.file.cache.evictor.TwoChoiceRandomEvictor
 
updateOnPut(PageId) - Method in class alluxio.client.file.cache.evictor.UnevictableCacheEvictor
 
updatePinList(Set<Long>) - Method in interface alluxio.worker.block.BlockWorker
Sets the pinlist for the underlying block store.
updatePinnedInodes(Set<Long>) - Method in interface alluxio.worker.block.BlockStore
Update the pinned inodes.
updateService(DefaultServiceEntity) - Method in class alluxio.membership.ServiceDiscoveryRecipe
Update the service value with new value.
updateState(BackupState) - Method in class alluxio.master.backup.BackupTracker
Updates the state of backup status.
updateStatSize(FileStat, long) - Static method in class alluxio.fuse.AlluxioFuseUtils
Updates file status size.
updateTasks(List<TaskInfo>) - Method in class alluxio.master.job.plan.PlanCoordinator
Updates internal status with given tasks.
UPDATETIMESTAMPS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPOptions
 
updateToRemovedBlock(boolean, long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Adds or removes a block from the to-be-removed blocks set of the worker.
updateUfsMode(AlluxioURI, UpdateUfsModePOptions) - Method in interface alluxio.client.file.FileSystemMasterClient
Updates the operation mode for the given ufs path.
updateUfsMode(AlluxioURI, UpdateUfsModePOptions) - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
updateUfsMode(UpdateUfsModePRequest, StreamObserver<UpdateUfsModePResponse>) - Method in interface alluxio.grpc.FileSystemMasterClientServiceGrpc.AsyncService
Updates the ufs mode for a ufs path under one or more mount points.
updateUfsMode(UpdateUfsModePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceBlockingStub
Updates the ufs mode for a ufs path under one or more mount points.
updateUfsMode(UpdateUfsModePRequest) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceFutureStub
Updates the ufs mode for a ufs path under one or more mount points.
updateUfsMode(UpdateUfsModePRequest, StreamObserver<UpdateUfsModePResponse>) - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceStub
Updates the ufs mode for a ufs path under one or more mount points.
UpdateUfsMode - Class in alluxio.master.backcompat.ops
Test for updating UFS modes.
UpdateUfsMode() - Constructor for class alluxio.master.backcompat.ops.UpdateUfsMode
 
updateUfsMode(AlluxioURI, UfsMode) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
updateUfsMode(AlluxioURI, UfsMode) - Method in interface alluxio.master.file.FileSystemMaster
Update the operation mode for the given ufs path under one or more mount points.
updateUfsMode(UpdateUfsModePRequest, StreamObserver<UpdateUfsModePResponse>) - Method in class alluxio.master.file.FileSystemMasterClientServiceHandler
 
UpdateUfsModePOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateUfsModePOptions
UpdateUfsModePOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateUfsModePOptions
UpdateUfsModePOptionsOrBuilder - Interface in alluxio.grpc
 
UpdateUfsModePRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateUfsModePRequest
UpdateUfsModePRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateUfsModePRequest
UpdateUfsModePRequestOrBuilder - Interface in alluxio.grpc
 
UpdateUfsModePResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateUfsModePResponse
UpdateUfsModePResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.file.UpdateUfsModePResponse
UpdateUfsModePResponseOrBuilder - Interface in alluxio.grpc
 
updateUsage(StorageTierAssoc, List<String>, Map<String, Long>, Map<String, Long>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Updates the worker storage usage.
updateUsedBytes(Map<String, Long>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Sets the used space of the worker in bytes.
updateUsedBytes(String, long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Sets the used space of the worker in bytes.
updateValues(Set<Metric>) - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
updateValues(Set<Metric>) - Method in interface alluxio.metrics.MultiValueMetricsAggregator
Updates the aggregated values from the filtered metrics.
updateWorkers() - Method in class alluxio.master.scheduler.Scheduler
Update workers.
updateWorkers() - Method in class alluxio.master.scheduler.Scheduler.WorkerInfoHub
Refresh active workers.
updateWorkingSetSize() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
Update working set size in number of pages and bytes.
updateWorkingSetSize() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
updateWorkingSetSize() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
updateWorkingSetSize() - Method in interface alluxio.client.file.cache.ShadowCacheManager
Update working set size in number of pages and bytes.
upgrade() - Method in class alluxio.master.journal.raft.JournalStateMachine
Upgrades the journal state machine to primary mode.
UPLOAD_ALREADY_EXISTS - Static variable in class alluxio.s3.S3ErrorCode.Name
 
UPLOAD_ALREADY_EXISTS - Static variable in class alluxio.s3.S3ErrorCode
 
UPLOAD_THRESHOLD - Static variable in class alluxio.underfs.ObjectLowLevelOutputStream
Only parts bigger than 5MB could be uploaded through multipart upload, except the last part.
uploadPart() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
Uploads part async.
uploadPart(File, int, boolean) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
uploadPart() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
Uploads part async.
uploadPart(byte[], int, boolean, long) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
uploadPartInternal(byte[], int, boolean, long) - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
uploadPartInternal(File, int, boolean, String) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
uploadPartInternal(byte[], int, boolean, long) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
uploadPartInternal(File, int, boolean, String) - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
uploadPartInternal(byte[], int, boolean, long) - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
uploadPartInternal(File, int, boolean, String) - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
uploadPartInternal(byte[], int, boolean, long) - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
uploadPartInternal(File, int, boolean, String) - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
uploadPartInternal(byte[], int, boolean, long) - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
UPLOADS_BUCKET_XATTR_KEY - Static variable in class alluxio.s3.S3Constants
 
UPLOADS_FILE_ID_XATTR_KEY - Static variable in class alluxio.s3.S3Constants
 
UPLOADS_OBJECT_XATTR_KEY - Static variable in class alluxio.s3.S3Constants
 
uploadSnapshot(StreamObserver<UploadSnapshotPResponse>) - Method in interface alluxio.grpc.RaftJournalServiceGrpc.AsyncService
Deprecated.
uploadSnapshot(StreamObserver<UploadSnapshotPResponse>) - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceStub
Deprecated.
UploadSnapshotPRequest - Class in alluxio.grpc
Deprecated.
UploadSnapshotPRequest.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.UploadSnapshotPRequest
UploadSnapshotPRequestOrBuilder - Interface in alluxio.grpc
Deprecated.
UploadSnapshotPResponse - Class in alluxio.grpc
Deprecated.
UploadSnapshotPResponse.Builder - Class in alluxio.grpc
Deprecated.
Protobuf type alluxio.grpc.meta.UploadSnapshotPResponse
UploadSnapshotPResponseOrBuilder - Interface in alluxio.grpc
Deprecated.
UPTIMEMS_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
URI - Interface in alluxio.uri
This interface represents a URI.
URI.Factory - Class in alluxio.uri
Factory for URI.
URI_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsInfo
 
UriCheckTask - Class in alluxio.cli.hms
A Task which given an input string, checks that the input is a valid connection string for to the Hive Metastore.
UriCheckTask(String, int) - Constructor for class alluxio.cli.hms.UriCheckTask
Creates a new UriCheckTask.
URIStatus - Class in alluxio.client.file
Wrapper around FileInfo.
URIStatus(FileInfo) - Constructor for class alluxio.client.file.URIStatus
Constructs an instance of this class from a FileInfo.
URIStatus(FileInfo, CacheContext) - Constructor for class alluxio.client.file.URIStatus
Constructs an instance of this class from a FileInfo.
URIStatusNameComparator() - Constructor for class alluxio.proxy.s3.S3RestUtils.URIStatusNameComparator
 
URIUtils - Class in alluxio.util
Utility methods for working with URIs.
usage() - Static method in class alluxio.cli.fsadmin.command.DoctorCommand
 
usage() - Static method in class alluxio.cli.fsadmin.command.ReportCommand
 
USE_MOUNT_CONF - Static variable in class alluxio.stress.worker.UfsIOParameters
 
used() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
used() - Method in interface alluxio.client.file.cache.CacheUsageView
Bytes currently used by the cache.
USED_BYTES_ON_TIERS_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
USED_BYTES_ON_TIERS = 7;
USED_BYTES_VALUE - Static variable in enum alluxio.grpc.BlockMasterInfoField
USED_BYTES = 6;
USEDBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
USEDBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
USEDBYTESONTIER_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
USEDBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
 
USEDBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockMasterInfo
 
USEDBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
USEDBYTESONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
useDisplayValue(boolean) - Method in class alluxio.conf.ConfigurationValueOptions
 
USEMULTIPARTUPLOAD_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
User - Class in alluxio.security
This class represents a user in Alluxio.
User(String) - Constructor for class alluxio.security.User
Constructs a new user with a name.
USER_AGENT_SEPARATOR - Static variable in class alluxio.check.UpdateCheck
 
USER_APP_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_APP_ID - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_AVOID_EVICTION_POLICY_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_AVOID_EVICTION_POLICY_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_READ_METRICS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_METRICS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_DIRS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_DIRS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_FILTER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_FILTER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_FILTER_CONFIG_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_FILTER_CONFIG_FILE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_IN_STREAM_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_IN_STREAM_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_BLOOMFILTER_NUM - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_BLOOMFILTER_NUM - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_CLOCK_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_CLOCK_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SCOPE_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SCOPE_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_ENCODER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_ENCODER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_PREFIX_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_PREFIX_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_SUFFIX_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_SUFFIX_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_MEMORY_OVERHEAD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_MEMORY_OVERHEAD - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_TYPE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_TTL_CHECK_INTERVAL_SECONDS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_TTL_CHECK_INTERVAL_SECONDS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_TTL_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_TTL_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_TTL_THRESHOLD_SECONDS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_TTL_THRESHOLD_SECONDS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_REPORT_VERSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_REPORT_VERSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CONF_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CONF_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
USER_CONSISTENT_HASH_VIRTUAL_NODE_COUNT_PER_WORKER - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CONSISTENT_HASH_VIRTUAL_NODE_COUNT_PER_WORKER - Static variable in class alluxio.conf.PropertyKey
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.conf.PropertyKey
 
USER_DYNAMIC_CONSISTENT_HASH_RING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_DYNAMIC_CONSISTENT_HASH_RING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsReadOptions
 
USER_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
USER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
USER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
USER_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_CREATE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_CREATE_TTL - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_CREATE_TTL_ACTION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_CREATE_TTL_ACTION - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_INCLUDE_OPERATION_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_INCLUDE_OPERATION_ID - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_METADATA_LOAD_REAL_CONTENT_HASH - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_METADATA_LOAD_REAL_CONTENT_HASH - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PERSIST_ON_RENAME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PERSIST_ON_RENAME - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PERSISTENCE_INITIAL_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PERSISTENCE_INITIAL_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_DURABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_DURABLE - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_SEQUENTIAL_PREAD_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_TARGET_MEDIA - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_TARGET_MEDIA - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_INIT_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_INIT_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_HDFS_CLIENT_EXCLUDE_MOUNT_INFO_ON_LIST_STATUS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_HDFS_CLIENT_EXCLUDE_MOUNT_INFO_ON_LIST_STATUS - Static variable in class alluxio.conf.PropertyKey
 
USER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
USER_LOCAL_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOCAL_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_LOCAL_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOCAL_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
USER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey
 
USER_MASTER_POLLING_CONCURRENT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_MASTER_POLLING_CONCURRENT - Static variable in class alluxio.conf.PropertyKey
 
USER_MASTER_POLLING_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_MASTER_POLLING_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_METADATA_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METADATA_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_METADATA_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METADATA_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_METRICS_COLLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METRICS_COLLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_METRICS_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METRICS_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETTY_DATA_TRANSMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETTY_DATA_TRANSMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_DATA_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_DATA_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_NETTY_CHANNEL_POOL_DISABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_DISABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_RPC_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey
USER_POSITION_READER_STREAMING_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_POSITION_READER_STREAMING_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_SHUFFLE_MASTERS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_SHUFFLE_MASTERS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_DATA_READ_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_DATA_READ_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_DATA_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_DATA_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_DATA_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_READER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_READER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_LOCATION_ALL_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_LOCATION_ALL_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_UPDATE_FILE_ACCESSTIME_DISABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UPDATE_FILE_ACCESSTIME_DISABLED - Static variable in class alluxio.conf.PropertyKey
 
User_VALUE - Static variable in enum alluxio.grpc.ErrorType
User = 0;
USER_VALUE - Static variable in enum alluxio.grpc.table.PrincipalType
USER = 0;
USER_WORKER_LIST_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_WORKER_LIST_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
USER_WORKER_SELECTION_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_WORKER_SELECTION_POLICY - Static variable in class alluxio.conf.PropertyKey
 
USERACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AccessControlList
 
useRawValue(boolean) - Method in class alluxio.conf.ConfigurationValueOptions
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class alluxio.network.netty.IdleWriteHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class alluxio.worker.netty.IdleReadHandler
 
userKeySet() - Method in interface alluxio.conf.AlluxioConfiguration
 
userKeySet() - Method in class alluxio.conf.AlluxioProperties
 
userKeySet() - Method in class alluxio.conf.InstancedConfiguration
 
userKeySet() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
UserLimitValidationTask - Class in alluxio.cli
Task for validating system limit for current user.
UserState - Interface in alluxio.security.user
UserState handles logging in any client, and maintains the state.
UserState.Factory - Class in alluxio.security.user
A factory for creating a UserState.
UserStateFactory - Interface in alluxio.security.user
A factory for creating new UserState instances.
Utils - Class in alluxio.master.backcompat
Util methods.
Utils - Class in alluxio.multi.process
Utility methods for external test cluster classes.
utimens(String, long, long, long, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
utimens(String, long, long, long, long) - Method in class alluxio.fuse.StackFS
 
utimens(String, long, long, long, long) - Method in interface alluxio.jnifuse.FuseFileSystem
 
utimensCallback(String, long, long, long, long) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
UUID_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePRequest
 
UUID_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePResponse
 

V

validate(Map<String, String>) - Method in class alluxio.cli.AbstractValidationTask
 
validate(String...) - Static method in class alluxio.cli.ValidateEnv
Validates environment.
validate(Map<String, String>) - Method in interface alluxio.cli.ValidationTask
Runs the validation task.
validate() - Method in interface alluxio.conf.AlluxioConfiguration
Validates the configuration.
validate() - Method in class alluxio.conf.InstancedConfiguration
 
validate() - Method in class alluxio.network.protocol.RPCMessage
Validates the message.
validate() - Method in class alluxio.network.protocol.RPCProtoMessage
 
validate() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
validate(Route, WriteOptions, FileSystem, FileSystem, boolean) - Static method in class alluxio.worker.task.ValidateHandler
Validates a file from source to destination.
validateArgs(CommandLine) - Method in class alluxio.cli.bundler.command.AbstractCollectInfoCommand
 
validateArgs(CommandLine) - Method in interface alluxio.cli.Command
Checks if the arguments are valid or throw InvalidArgumentException.
validateArgs(CommandLine) - Method in class alluxio.cli.extensions.command.InstallCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.extensions.command.LsCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.extensions.command.UninstallCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CatCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CheckCachedCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChecksumCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChgrpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChmodCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ChownCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.ConsistentHashCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.CpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.FreeCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.HeadCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.HelpCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LoadCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LocationCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.LsCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MkdirCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.MvCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.RmCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.StatCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.TailCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.TestCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fs.command.TouchCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.BackupCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.DoctorCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.command.ReportCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.journal.CheckpointCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.journal.QuorumInfoCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
validateArgs(CommandLine) - Method in class alluxio.cli.fsadmin.metrics.ClearCommand
 
validateArgs(String[]) - Method in interface alluxio.cli.FuseCommand
Checks if the arguments are valid or throw InvalidArgumentException.
ValidateConf - Class in alluxio.cli
Validate the Alluxio configuration.
validateDateAndExpires(Map<String, String>) - Static method in class alluxio.s3.signature.utils.AwsAuthV4QueryParserUtils
 
validateDateRange(String, String) - Static method in class alluxio.s3.signature.AwsCredential
validate credential info.
ValidateEnv - Class in alluxio.cli
Utility for checking Alluxio environment.
ValidateEnv(String, AlluxioConfiguration) - Constructor for class alluxio.cli.ValidateEnv
Initializes from the target UFS path and configurations.
validateFuseConfAndOptions(AlluxioConfiguration, FuseOptions) - Static method in class alluxio.fuse.AlluxioFuse
 
ValidateHandler - Class in alluxio.worker.task
ValidateHandler is responsible for validating files at source and destination.
ValidateHandler() - Constructor for class alluxio.worker.task.ValidateHandler
 
ValidateHdfsMount - Class in alluxio.cli
A tool to validate an HDFS mount, before the path is mounted to Alluxio.
ValidateHdfsMount() - Constructor for class alluxio.cli.ValidateHdfsMount
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.AbstractValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.ClusterConfConsistencyValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.hdfs.HdfsConfParityValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.hdfs.HdfsConfValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.hdfs.HdfsProxyUserValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.hdfs.HdfsVersionValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.hdfs.SecureHdfsValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.hms.CreateHmsClientValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.hms.MetastoreValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.NativeLibValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.PortAvailabilityValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.RamDiskMountPrivilegeValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.SshValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.StorageSpaceValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.UfsDirectoryValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.UfsSuperUserValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.UfsVersionValidationTask
 
validateImpl(Map<String, String>) - Method in class alluxio.cli.UserLimitValidationTask
 
validateMountPoint(AlluxioURI, AlluxioURI, long, MountPOptions) - Method in class alluxio.master.file.meta.MountTable
Verify if the given (alluxioPath, ufsPath) can be inserted into MountTable.
validateParams() - Method in class alluxio.stress.cli.AbstractStressBench
Validates the parameters.
validateParams() - Method in class alluxio.stress.cli.client.StressClientIOBench
 
validateParams() - Method in class alluxio.stress.cli.worker.StressWorkerBench
 
validateParts(CompleteMultipartUploadRequest, String, AlluxioURI) - Method in class alluxio.proxy.s3.CompleteMultipartUploadHandler.CompleteMultipartUploadTask
Validate the parts as part of this multipart uplaod request.
validateParts(CompleteMultipartUploadRequest, String, AlluxioURI) - Method in class alluxio.proxy.s3.S3ObjectTask.CompleteMultipartUploadTask
Validate the parts as part of this multipart uplaod request.
validatePath(String, AlluxioConfiguration) - Static method in class alluxio.cli.fs.FileSystemShellUtils
Validates the path, verifying that it contains the Constants.HEADER and a hostname:port specified.
validatePath(String) - Static method in class alluxio.underfs.BaseUnderFileSystem
Clean the path by creating a URI and turning it back to a string.
validatePath(String) - Static method in class alluxio.util.io.PathUtils
Checks if the given path is properly formed.
validateRequest(String, String, String) - Static method in class alluxio.s3.signature.AuthorizationV4Validator
Validate request by comparing Signature from request.
validateUfs() - Method in class alluxio.cli.HdfsValidationTool
 
validateValue(Object) - Method in class alluxio.conf.PropertyKey
 
ValidationConfig - Class in alluxio.cli
Configuration settings for the validation tools.
ValidationConfig() - Constructor for class alluxio.cli.ValidationConfig
 
ValidationResults - Class in alluxio.cli
A container class for the validation results.
ValidationResults() - Constructor for class alluxio.cli.ValidationResults
 
ValidationTask - Interface in alluxio.cli
Interface for a validation task run by validateEnv command.
ValidationTaskResult - Class in alluxio.cli
Represents the result of a given task.
ValidationTaskResult(ValidationUtils.State, String, String, String) - Constructor for class alluxio.cli.ValidationTaskResult
Creates a new ValidationTaskResult.
ValidationTaskResult(ValidationUtils.State, String, String, String, String) - Constructor for class alluxio.cli.ValidationTaskResult
Creates a new ValidationTaskResult.
ValidationTaskResult() - Constructor for class alluxio.cli.ValidationTaskResult
Creates a new ValidationTaskResult.
ValidationTool - Interface in alluxio.cli
The validation tool interface.
ValidationToolFactory - Interface in alluxio.cli
The validation tool factory interface.
ValidationToolRegistry - Class in alluxio.cli
The registry of validation tool implementations.
ValidationToolRegistry(AlluxioConfiguration) - Constructor for class alluxio.cli.ValidationToolRegistry
Creates a new instance of an ValidationToolRegistry.
ValidationUtils - Class in alluxio.cli
Utilities to run the validation tests.
ValidationUtils.State - Enum in alluxio.cli
Task State.
Value(FileSystem, int) - Constructor for class alluxio.client.file.FileSystemCache.Value
 
Value - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Value
value() - Method in enum alluxio.jnifuse.constants.Errno
 
Value.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.Value
Value.ValueCase - Enum in alluxio.grpc.table
 
VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigProperty
 
VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.LocationBlockIdListEntry
 
VALUE_FIELD_NUMBER - Static variable in class alluxio.grpc.Metric
 
VALUE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.StringPairEntry
 
VALUE_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.FileFilter
 
valueAsString(String) - Static method in class alluxio.util.ConfigurationUtils
 
valueOf(String) - Static method in enum alluxio.annotation.dora.DoraTestTodoItem.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.BaseFileStructure.Distribution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.cli.ApplicableUfsType.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.cli.Format.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.cli.fsadmin.command.DecommissionWorkerCommand.ReturnCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.cli.ValidationUtils.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.AlluxioStorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.cache.CacheManager.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.cache.CacheManagerWithShadowCache.PageIdFunnel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.cache.cuckoofilter.SlidingWindowType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.cache.ShadowCacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.cache.store.PageStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.CacheContext.StatsUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.dora.netty.PartialReadException.CauseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.FileSystemContext.GetWorkerListType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.quota.CacheScope.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.ReadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.UnderStorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.WriteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.concurrent.LockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.ConsistencyCheckLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.DisplayType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.PropertyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.Template
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.Source.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.exception.ExceptionMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.exception.PreconditionMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.executor.ExecutorServiceBuilder.RpcExecutorHost
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.executor.RpcExecutorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.executor.ThreadPoolExecutorQueueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.file.options.DescendantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.fsmaster.FileSystemBase.ServerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.fuse.AlluxioFuseOpenUtils.OpenAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.grpc.BackupState
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.BackupState
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.BackupState
 
valueOf(String) - Static method in enum alluxio.grpc.Bits
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.Bits
Deprecated.
Use Bits.forNumber(int) instead.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.Bits
 
valueOf(String) - Static method in enum alluxio.grpc.BlockMasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.BlockMasterInfoField
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.BlockMasterInfoField
 
valueOf(String) - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
 
valueOf(String) - Static method in enum alluxio.grpc.CommandType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.CommandType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.CommandType
 
valueOf(String) - Static method in enum alluxio.grpc.ConfigStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.ConfigStatus
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.ConfigStatus
 
valueOf(String) - Static method in enum alluxio.grpc.ErrorType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.ErrorType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.ErrorType
 
valueOf(String) - Static method in enum alluxio.grpc.GrpcNetworkGroup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.grpc.JobMasterMetaCommand
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.JobMasterMetaCommand
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.JobMasterMetaCommand
 
valueOf(String) - Static method in enum alluxio.grpc.JobProgressReportFormat
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.JobProgressReportFormat
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.JobProgressReportFormat
 
valueOf(String) - Static method in enum alluxio.grpc.JobSource
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.JobSource
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.JobSource
 
valueOf(String) - Static method in enum alluxio.grpc.JobType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.JobType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.JobType
 
valueOf(String) - Static method in enum alluxio.grpc.JournalDomain
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.JournalDomain
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.JournalDomain
 
valueOf(String) - Static method in enum alluxio.grpc.ListStatusPartialPOptions.OffsetTypeCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.ListStatusPartialPOptions.OffsetTypeCase
valueOf(String) - Static method in enum alluxio.grpc.LoadDescendantPType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.LoadDescendantPType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.LoadDescendantPType
 
valueOf(String) - Static method in enum alluxio.grpc.LoadMetadataPType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.LoadMetadataPType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.LoadMetadataPType
 
valueOf(String) - Static method in enum alluxio.grpc.MasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.MasterInfoField
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.MasterInfoField
 
valueOf(String) - Static method in enum alluxio.grpc.MetaCommand
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.MetaCommand
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.MetaCommand
 
valueOf(String) - Static method in enum alluxio.grpc.MetricType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.MetricType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.MetricType
 
valueOf(String) - Static method in enum alluxio.grpc.NodeState
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.NodeState
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.NodeState
 
valueOf(String) - Static method in enum alluxio.grpc.OperationType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.OperationType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.OperationType
 
valueOf(String) - Static method in enum alluxio.grpc.PAclAction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.PAclAction
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.PAclAction
 
valueOf(String) - Static method in enum alluxio.grpc.PAclEntryType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.PAclEntryType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.PAclEntryType
 
valueOf(String) - Static method in enum alluxio.grpc.QuorumServerState
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.QuorumServerState
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.QuorumServerState
 
valueOf(String) - Static method in enum alluxio.grpc.ReadPType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.ReadPType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.ReadPType
 
valueOf(String) - Static method in enum alluxio.grpc.RequestType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.RequestType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.RequestType
 
valueOf(String) - Static method in enum alluxio.grpc.SaslMessageType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.SaslMessageType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.SaslMessageType
 
valueOf(String) - Static method in enum alluxio.grpc.Scope
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.Scope
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.Scope
 
valueOf(String) - Static method in enum alluxio.grpc.ServiceType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.ServiceType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.ServiceType
 
valueOf(String) - Static method in enum alluxio.grpc.SetAclAction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.SetAclAction
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.SetAclAction
 
valueOf(String) - Static method in enum alluxio.grpc.Status
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.Status
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.Status
 
valueOf(String) - Static method in enum alluxio.grpc.SyncPointStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.SyncPointStatus
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.SyncPointStatus
 
valueOf(String) - Static method in enum alluxio.grpc.table.ColumnStatisticsData.DataCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.table.ColumnStatisticsData.DataCase
valueOf(String) - Static method in enum alluxio.grpc.table.Domain.ValueSetCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.table.Domain.ValueSetCase
Deprecated.
valueOf(String) - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
 
valueOf(String) - Static method in enum alluxio.grpc.table.PrincipalType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.table.PrincipalType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.table.PrincipalType
 
valueOf(String) - Static method in enum alluxio.grpc.table.TableInfo.TableType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.table.TableInfo.TableType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.table.TableInfo.TableType
 
valueOf(String) - Static method in enum alluxio.grpc.table.Value.ValueCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.table.Value.ValueCase
Deprecated.
valueOf(String) - Static method in enum alluxio.grpc.TaskStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.TaskStatus
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.TaskStatus
 
valueOf(String) - Static method in enum alluxio.grpc.TtlAction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.TtlAction
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.TtlAction
 
valueOf(String) - Static method in enum alluxio.grpc.UfsPMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.UfsPMode
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.UfsPMode
 
valueOf(String) - Static method in enum alluxio.grpc.WorkerInfoField
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.WorkerInfoField
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.WorkerInfoField
 
valueOf(String) - Static method in enum alluxio.grpc.WorkerRange
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.WorkerRange
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.WorkerRange
 
valueOf(String) - Static method in enum alluxio.grpc.WritePType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.WritePType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.WritePType
 
valueOf(String) - Static method in enum alluxio.grpc.WriteRequest.ValueCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.WriteRequest.ValueCase
Deprecated.
valueOf(String) - Static method in enum alluxio.grpc.XAttrPropagationStrategy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.grpc.XAttrPropagationStrategy
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.grpc.XAttrPropagationStrategy
 
valueOf(String) - Static method in enum alluxio.heartbeat.HeartbeatContext.HeartbeatType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.heartbeat.HeartbeatThread.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.jnifuse.constants.Errno
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.jnifuse.utils.LibfuseVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.jnifuse.utils.NativeLibraryLoader.LoadState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.job.plan.PlanDefinitionRegistry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.job.plan.replicate.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.job.wire.JobSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.job.wire.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.job.workflow.WorkflowExecutionRegistry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.block.meta.WorkerMetaLockSection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.contexts.CallTracker.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.DefaultFileSystemMaster.Metrics.UFSOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.InodeSyncStream.SyncStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.meta.InodeTree.LockPattern
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.meta.PersistenceState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.MetadataSyncTraversalOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.PersistJob.CancelState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.GraceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.checkpoint.CheckpointName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.checkpoint.CheckpointType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.JournalReader.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.JournalSystem.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.JournalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.ufs.UfsJournalCheckpointThread.CatchupState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.MasterHealthCheckClient.MasterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.metastore.MetastoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.metastore.rocks.DataBlockIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.metastore.rocks.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.selectionpolicy.MasterSelectionPolicy.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.transport.GrpcMessagingConnection.ConnectionOwner
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.WorkerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.ZookeeperConnectionErrorPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.membership.MembershipType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.metrics.MetricInfo.UfsOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.multi.process.MultiProcessCluster.DeployMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.ChannelType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.netty.FileTransferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
 
valueOf(String) - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
 
valueOf(String) - Static method in enum alluxio.proto.journal.File.PSetAclAction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.journal.File.PSetAclAction
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.journal.File.PSetAclAction
 
valueOf(String) - Static method in enum alluxio.proto.journal.File.PTtlAction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.journal.File.PTtlAction
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.journal.File.PTtlAction
 
valueOf(String) - Static method in enum alluxio.proto.journal.File.UfsMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.journal.File.UfsMode
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.journal.File.UfsMode
 
valueOf(String) - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
 
valueOf(String) - Static method in enum alluxio.proto.journal.Job.PJobState
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.journal.Job.PJobState
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.journal.Job.PJobState
 
valueOf(String) - Static method in enum alluxio.proto.shared.Acl.AclAction
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.shared.Acl.AclAction
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.shared.Acl.AclAction
 
valueOf(String) - Static method in enum alluxio.proto.shared.Acl.AclEntryType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.shared.Acl.AclEntryType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.shared.Acl.AclEntryType
 
valueOf(String) - Static method in enum alluxio.proto.status.Status.PStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum alluxio.proto.status.Status.PStatus
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum alluxio.proto.status.Status.PStatus
 
valueOf(String) - Static method in enum alluxio.proxy.s3.S3BaseTask.OpTag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.proxy.s3.S3BaseTask.OpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.resource.DynamicResourcePool.SelectionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.s3.S3Constants.Directive
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.s3.signature.SignatureInfo.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.scheduler.job.JobState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authentication.AuthType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.AclAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.AclEntryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.Mode.Bits
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.stress.client.ClientIOOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.stress.common.FileSystemClientType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.stress.worker.IOTaskResult.IOMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.time.ExponentialTimer.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.ChecksumType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.hdfs.HdfsVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.UfsMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.UnderFileSystem.SpaceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.util.CommonUtils.ProcessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.util.compression.DirectoryMarshaller.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.CommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.LoadMetadataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.BlockStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.io.BlockClient.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.management.BackoffStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.s3.S3NettyBaseTask.OpTag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.s3.S3NettyBaseTask.OpType
Returns the enum constant of this type with the specified name.
ValueOrBuilder - Interface in alluxio.grpc.table
 
values() - Static method in enum alluxio.annotation.dora.DoraTestTodoItem.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.BaseFileStructure.Distribution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.cli.ApplicableUfsType.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.cli.Format.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.cli.fsadmin.command.DecommissionWorkerCommand.ReturnCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.cli.ValidationUtils.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.AlluxioStorageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerRange
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.cache.CacheManager.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.cache.CacheManagerWithShadowCache.PageIdFunnel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.cache.cuckoofilter.SlidingWindowType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.cache.ShadowCacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.cache.store.PageStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.CacheContext.StatsUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.dora.netty.NettyDataReaderStateMachine.TriggerEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.dora.netty.PartialReadException.CauseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.FileSystemContext.GetWorkerListType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.quota.CacheScope.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.ReadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.UnderStorageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.WriteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
values() - Static method in enum alluxio.concurrent.LockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.ConsistencyCheckLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.DisplayType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.PropertyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.Template
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.Source.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.exception.ExceptionMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.exception.PreconditionMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.executor.ExecutorServiceBuilder.RpcExecutorHost
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.executor.RpcExecutorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.executor.ThreadPoolExecutorQueueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.file.options.DescendantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.fsmaster.FileSystemBase.ServerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.fuse.AlluxioFuseOpenUtils.OpenAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.BackupState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.Bits
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.BlockMasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.ChannelAuthenticationScheme
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.ConfigStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.ErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.GrpcNetworkGroup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.JobMasterMetaCommand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.JobProgressReportFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.JobSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.JobType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.JournalDomain
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.ListStatusPartialPOptions.OffsetTypeCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.LoadDescendantPType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.LoadMetadataPType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.MasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.MetaCommand
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.MetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.NodeState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.PAclAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.PAclEntryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.QuorumServerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.ReadPType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.SaslMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.SetAclAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.SyncPointStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.table.ColumnStatisticsData.DataCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.table.Domain.ValueSetCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.table.PrincipalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.table.TableInfo.TableType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.table.Value.ValueCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.TaskStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.TtlAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.UfsPMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.WorkerInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.WorkerRange
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.WritePType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.WriteRequest.ValueCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.XAttrPropagationStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.heartbeat.HeartbeatContext.HeartbeatType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.heartbeat.HeartbeatThread.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.jnifuse.constants.Errno
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.jnifuse.utils.LibfuseVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.jnifuse.utils.NativeLibraryLoader.LoadState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.job.plan.PlanDefinitionRegistry
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.job.plan.replicate.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.job.wire.JobSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.job.wire.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.job.workflow.WorkflowExecutionRegistry
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.block.meta.WorkerMetaLockSection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.contexts.CallTracker.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.DefaultFileSystemMaster.Metrics.UFSOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.InodeSyncStream.SyncStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.meta.InodeTree.LockPattern
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.meta.PersistenceState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.MetadataSyncTraversalOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.PersistJob.CancelState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.GraceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.checkpoint.CheckpointName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.checkpoint.CheckpointType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.JournalReader.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.JournalSystem.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.JournalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.ufs.UfsJournalCheckpointThread.CatchupState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.MasterHealthCheckClient.MasterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.metastore.MetastoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.metastore.rocks.DataBlockIndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.metastore.rocks.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.selectionpolicy.MasterSelectionPolicy.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.transport.GrpcMessagingConnection.ConnectionOwner
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.WorkerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.ZookeeperConnectionErrorPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.membership.MembershipType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.metrics.MetricInfo.UfsOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.multi.process.MultiProcessCluster.DeployMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.ChannelType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.netty.FileTransferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.dataserver.Protocol.ReadResponse.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.dataserver.Protocol.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.journal.File.PSetAclAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.journal.File.PTtlAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.journal.File.UfsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.journal.File.XAttrUpdateStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.journal.Job.PJobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.shared.Acl.AclAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.shared.Acl.AclEntryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proto.status.Status.PStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proxy.s3.S3BaseTask.OpTag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.proxy.s3.S3BaseTask.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.resource.DynamicResourcePool.SelectionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.s3.S3Constants.Directive
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.s3.signature.SignatureInfo.Version
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.scheduler.job.JobState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authentication.AuthType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.AclAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.AclEntryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.Mode.Bits
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.stress.client.ClientIOOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.stress.common.FileSystemClientType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.stress.worker.IOTaskResult.IOMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.time.ExponentialTimer.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.ChecksumType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.hdfs.HdfsVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.UfsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.UnderFileSystem.SpaceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.util.CommonUtils.ProcessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.util.compression.DirectoryMarshaller.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.LoadMetadataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.BlockStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.io.BlockClient.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.management.BackoffStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.s3.S3NettyBaseTask.OpTag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.s3.S3NettyBaseTask.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES_FIELD_NUMBER - Static variable in class alluxio.grpc.InconsistentProperty
 
VALUES_FIELD_NUMBER - Static variable in class alluxio.grpc.InconsistentPropertyValues
 
VALUES_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.PartitionInfo
 
VERBOSE_FIELD_NUMBER - Static variable in class alluxio.grpc.JobProgressPOptions
 
VERIFY_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyJobPOptions
 
VERIFY_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadJobPOptions
 
VERIFY_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveJobPOptions
 
VERIFY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
VERIFY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
VERIFY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
Version - Class in alluxio.cli
The version of the current build.
VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
VERSION - Static variable in class alluxio.conf.PropertyKey
 
Version - Class in alluxio.master.backcompat
Class for representing a version.
Version(int, int, int) - Constructor for class alluxio.master.backcompat.Version
 
VERSION - Static variable in class alluxio.master.journal.ufs.UfsJournal
The journal version.
VERSION - Static variable in class alluxio.ProjectConstants
 
VERSION - Static variable in class alluxio.RuntimeConstants
The version of this Alluxio instance.
VERSION - Static variable in class alluxio.security.authentication.plain.PlainSaslServerProvider
 
VERSION - Static variable in class alluxio.wire.WorkerIdentity.ParserV0
 
VERSION - Static variable in class alluxio.wire.WorkerIdentity.ParserV1
 
VERSION_AND_REVISION_SHORT - Static variable in class alluxio.RuntimeConstants
 
VERSION_CREATION_TIME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Partition
 
VERSION_CREATION_TIME_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.BuildVersion
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.GetServiceVersionPResponse
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.JobMasterStatus
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterVersion
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyHeartbeatPOptions
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyStatus
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobMasterPOptions
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobWorkerPRequest
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterMasterPOptions
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Partition
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.table.TableInfo
 
VERSION_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerIdentity
 
VERSION_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
VERSION = 6;
VersionProto - Class in alluxio.grpc
 

W

waitCompleted(FileSystem, AlluxioURI) - Static method in class alluxio.client.file.FileSystemUtils
Shortcut for waitCompleted(fs, uri, -1, TimeUnit.MILLISECONDS), i.e., wait for an indefinite amount of time.
waitCompleted(FileSystem, AlluxioURI, long, TimeUnit) - Static method in class alluxio.client.file.FileSystemUtils
Waits for a file to be marked as completed.
waitFor(boolean, InetSocketAddress) - Static method in class alluxio.master.service.rpc.RpcServerService
Creates a buffer between rejecting server and regular serving server of at most 1 second.
waitFor(String, Supplier<Boolean>) - Static method in class alluxio.util.CommonUtils
Waits for a condition to be satisfied.
waitFor(String, Supplier<Boolean>, WaitForOptions) - Static method in class alluxio.util.CommonUtils
Waits for a condition to be satisfied.
waitForAllNodesRegistered(int) - Method in class alluxio.multi.process.MultiProcessCluster
Waits for all nodes to be registered.
waitForAllPartsUpload() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
waitForAllPartsUpload() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
waitForAlluxioPercentage(FileSystem, AlluxioURI, int) - Static method in class alluxio.client.file.FileSystemUtils
Waits until the specified file has the desired percentage in Alluxio.
waitForAndKillPrimaryMaster(int) - Method in class alluxio.multi.process.MultiProcessCluster
Kills the primary master.
waitForAttemptToComplete() - Method in class alluxio.master.journal.raft.RaftSnapshotManager
Waits synchronously for the download attempt to be complete.
waitForBound() - Method in class alluxio.master.service.rpc.RpcServerService
 
waitForCatchup() - Method in interface alluxio.master.journal.JournalSystem
Waits for the journal catchup to finish when the process starts.
waitForCatchup() - Method in class alluxio.master.journal.ufs.UfsJournalSystem
 
waitForCmd(long) - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Waits for command to complete.
waitForCmdJob() - Method in class alluxio.master.job.tracker.AbstractCmdRunner
Waits for at least one job to complete.
waitForComplete(long) - Method in class alluxio.client.block.stream.GrpcBlockingStream
Wait for server to complete the inbound stream.
waitForComplete(long) - Method in class alluxio.client.block.stream.GrpcDataMessageBlockingStream
 
waitForFileCompleted(FileSystem, AlluxioURI) - Static method in class alluxio.fuse.AlluxioFuseUtils
Waits for the file to complete.
waitForFree() - Method in class alluxio.master.service.rpc.RpcServerService
 
waitForLeaderGrpcServerReady(int) - Method in class alluxio.master.MasterProcess
Waits until the grpc server is ready to serve requests.
waitForMasterServing() - Method in class alluxio.master.AbstractLocalAlluxioCluster
 
waitForMetricSinkServing(int) - Method in class alluxio.master.MasterProcess
Wait until the metrics sinks have been started.
waitForNewMaster(int) - Method in class alluxio.master.MultiMasterLocalAlluxioCluster
Waits for a new master to start until a timeout occurs.
WaitForOptions - Class in alluxio.util
waitForPrimaryMasterServing(int) - Method in class alluxio.master.MultiMasterEmbeddedJournalLocalAlluxioCluster
Waits for the primary master to start until a timeout occurs.
waitForReady(int) - Method in class alluxio.master.MasterProcess
 
waitForReady(Process) - Static method in class alluxio.master.TestUtils
 
waitForReady(int) - Method in interface alluxio.Process
Waits until the process is ready to serve requests.
waitForReady(int) - Method in class alluxio.proxy.AlluxioProxyProcess
 
waitForReady(int) - Method in class alluxio.worker.AlluxioJobWorkerProcess
 
waitForReady(int) - Method in class alluxio.worker.AlluxioWorkerProcess
 
waitForResult(String, Supplier<T>, Function<T, Boolean>) - Static method in class alluxio.util.CommonUtils
Waits for the object to meet a certain condition.
waitForResult(String, Supplier<T>, Function<T, Boolean>, WaitForOptions) - Static method in class alluxio.util.CommonUtils
Waits for the object to meet a certain condition.
waitForState(NodeState) - Method in class alluxio.master.AbstractPrimarySelector
 
waitForState(NodeState) - Method in class alluxio.master.AlwaysStandbyPrimarySelector
 
waitForState(NodeState) - Method in interface alluxio.master.PrimarySelector
Blocks until the primary selector enters the specified state.
waitForWebServerReady(int) - Method in class alluxio.master.MasterProcess
Waits until the web server is ready to serve requests.
waitForWorkersRegistered(int) - Method in class alluxio.master.AbstractLocalAlluxioCluster
Waits for all workers registered with master.
waitJob() - Method in class alluxio.cli.fs.command.AbstractDistributedJobCommand
Waits for at least one job to complete.
waitTermination() - Method in class alluxio.master.journal.AbstractCatchupThread
Waits until catching up is finished (completed/cancelled).
waitTermination() - Method in class alluxio.master.journal.CatchupFuture
Waits until advancing finishes.
waitUntilFinished() - Method in class alluxio.master.backup.BackupTracker
Used to wait until this backup is finished.
waitUntilFinished(long, TimeUnit) - Method in class alluxio.master.backup.BackupTracker
Used to wait until this backup is finished.
warmUpLoop() - Static method in class alluxio.util.CommonUtils
Common empty loop utility that serves the purpose of warming up the JVM before performance microbenchmarks.
warn(String) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
WARN_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey.Name
 
WARN_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey
 
WARN_VALUE - Static variable in enum alluxio.grpc.ConfigStatus
WARN = 2;
WARNS_FIELD_NUMBER - Static variable in class alluxio.grpc.ConfigCheckReport
 
warnWithException(Logger, String, Object...) - Static method in class alluxio.util.LogUtils
Log a warning message with full exception if debug logging is enabled, or just the exception string otherwise.
WasbUnderFileSystem - Class in alluxio.underfs.wasb
An UnderFileSystem uses the Microsoft Azure Blob Storage.
WasbUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.wasb.WasbUnderFileSystem
Constructs a new Wasb UnderFileSystem.
WasbUnderFileSystemFactory - Class in alluxio.underfs.wasb
Factory for creating WasbUnderFileSystem.
WasbUnderFileSystemFactory() - Constructor for class alluxio.underfs.wasb.WasbUnderFileSystemFactory
Constructs a new WasbUnderFileSystemFactory.
wasSyncPerformed() - Method in class alluxio.master.file.meta.SyncCheck.SyncResult
 
WEB_CORS_ALLOW_CREDENTIAL - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_ALLOW_CREDENTIAL - Static variable in class alluxio.conf.PropertyKey
 
WEB_CORS_ALLOW_HEADERS - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_ALLOW_HEADERS - Static variable in class alluxio.conf.PropertyKey
 
WEB_CORS_ALLOW_METHODS - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_ALLOW_METHODS - Static variable in class alluxio.conf.PropertyKey
 
WEB_CORS_ALLOW_ORIGINS - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_ALLOW_ORIGINS - Static variable in class alluxio.conf.PropertyKey
 
WEB_CORS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WEB_CORS_EXPOSED_HEADERS - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_EXPOSED_HEADERS - Static variable in class alluxio.conf.PropertyKey
 
WEB_CORS_MAX_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_MAX_AGE - Static variable in class alluxio.conf.PropertyKey
 
WEB_FILE_INFO_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_FILE_INFO_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WEB_PORT_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
WEB_PORT = 7;
WEB_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
WEB_RESOURCES - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_RESOURCES - Static variable in class alluxio.conf.PropertyKey
 
WEB_THREAD_DUMP_TO_LOG - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_THREAD_DUMP_TO_LOG - Static variable in class alluxio.conf.PropertyKey
 
WEB_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WEB_UI_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_UI_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WebInterfaceAbstractMetricsServlet - Class in alluxio.web
Abstract class that provides a common method for parsing metrics data.
WebInterfaceAbstractMetricsServlet() - Constructor for class alluxio.web.WebInterfaceAbstractMetricsServlet
Creates a new instance of WebInterfaceAbstractMetricsServlet.
WEBPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
WEBPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerNetAddress
 
WebServer - Class in alluxio.web
Class that bootstraps and starts a web server.
WebServer(String, InetSocketAddress) - Constructor for class alluxio.web.WebServer
Creates a new instance of WebServer.
WebServerService - Class in alluxio.master.service.web
Defines common interface for the two difference web server behavior.
WebServerService(MasterProcess) - Constructor for class alluxio.master.service.web.WebServerService
 
WebServerService.Factory - Class in alluxio.master.service.web
Factory for WebServer service.
WEBUI_BROWSE - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_CONFIG - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_DATA - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_INIT - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_LOGS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_MASTERS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_METRICS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_MOUNTTABLE - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_OVERVIEW - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WEBUI_WORKERS - Static variable in class alluxio.master.meta.AlluxioMasterRestServiceHandler
 
WebUtils - Class in alluxio.util.webui
The type Web utils.
whenComplete(BiConsumer<? super T, ? super Throwable>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
whenComplete(BiConsumer<? super T, ? super Throwable>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage with the same result or exception as this stage, that executes the given action when this stage completes.
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage with the same result or exception as this stage, that executes the given action using this stage's default asynchronous execution facility when this stage completes.
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage with the same result or exception as this stage, that executes the given action using the supplied Executor when this stage completes.
WHITE_LIST_FIELD_NUMBER - Static variable in class alluxio.grpc.table.EquatableValueSet
 
WILDCARD - Static variable in class alluxio.AlluxioURI
 
WILDCARD - Static variable in class alluxio.security.authentication.ImpersonationAuthenticator
 
WILDCARD_ADDRESS - Static variable in class alluxio.util.network.NetworkAddressUtils
 
WINDOWS - Static variable in class alluxio.util.network.NetworkAddressUtils
Checks if the underlying OS is Windows.
withAlluxioMasterType(MasterHealthCheckClient.MasterType) - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
withChildOption(ChannelOption<T>, T) - Method in class alluxio.grpc.GrpcServerBuilder
Sets a netty channel option.
withCloseable(Closeable) - Method in class alluxio.grpc.GrpcService
Add a new closeable resource to this service's closer.
withConfiguration(AlluxioConfiguration) - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
withInitialSleep(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withMaxDuration(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withMaxSleep(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withModules(ImmutableList<Module>) - Static method in class alluxio.worker.WorkerProcess.Factory
 
withProcessCheck(boolean) - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
withRetryPolicy(Supplier<RetryPolicy>) - Method in class alluxio.master.MasterHealthCheckClient.Builder
 
withServerProxy(GrpcMessagingProxy) - Method in class alluxio.master.transport.GrpcMessagingTransport
Sets external proxy configuration for servers.
withSkipInitialSleep() - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
first sleep will be skipped.
withTimeCtx(TimeContext) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withTracker(CallTracker) - Method in class alluxio.master.file.contexts.OperationContext
Updates this context with a new tracker.
withZone(ZoneId) - Method in class alluxio.clock.ElapsedTimeClock
 
withZone(ZoneId) - Method in class alluxio.clock.SystemClock
 
WORK_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
WORK_DIR - Static variable in class alluxio.conf.PropertyKey
 
Worker(int, int, int, ByteBuffer) - Constructor for class alluxio.examples.Performance.Worker
 
Worker - Class in alluxio.multi.process
Class for running and interacting with an Alluxio worker in a separate process.
Worker(File, Map<PropertyKey, Object>) - Constructor for class alluxio.multi.process.Worker
 
Worker - Interface in alluxio.worker
Interface of an Alluxio worker.
WORKER_ACTIVE_CLIENTS - Static variable in class alluxio.metrics.MetricKey
Deprecated.
WORKER_ACTIVE_OPERATIONS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ACTIVE_RPC_READ_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ACTIVE_RPC_WRITE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ADDRESSES_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
WORKER_ADDRESSES = 8;
WORKER_ALL_MASTER_REGISTRATION - Static variable in class alluxio.multi.process.PortCoordination
 
WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_READER_COMPLETED_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_READER_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_READER_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_READER_THREAD_MAX_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_REMOVED_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_REMOVING_BLOCKS_SIZE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_TRY_REMOVE_BLOCKS_SIZE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_TRY_REMOVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_COMPLETED_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_THREAD_MAX_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_BLOCK_WRITER_COMPLETED_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_WRITER_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_WRITER_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_WRITER_THREAD_MAX_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_ACCESSED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_CACHED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_CANCELLED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_DELETED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_EVICTION_RATE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_LOST - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_PROMOTED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DIRECT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DIRECT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_BLOCKS_SIZE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_FAILED_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REMOTE_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REQUESTS_ASYNC - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REQUESTS_SYNC - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_SUCCEEDED_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_UFS_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_BYTES_ON_TIERS_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
WORKER_CAPACITY_BYTES_ON_TIERS = 3;
WORKER_CAPACITY_BYTES_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
WORKER_CAPACITY_BYTES = 2;
WORKER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CLIENT - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_CONTAINER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_CONTAINER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_FOLDER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_FOLDER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.conf.PropertyKey
Directory Permission Handling for Legacy Short-Circuit Read/Write.
WORKER_DATA_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.conf.PropertyKey
 
WORKER_ERROR_THRESHOLD - Static variable in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand.WorkerStatus
 
WORKER_FILE_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FILE_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_FILESYSTEM_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_FREE_SPACE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FREE_SPACE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_FUSE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FUSE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_FUSE_MOUNT_ALLUXIO_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FUSE_MOUNT_OPTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FUSE_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_GET_FILE_INFO_EXTERNAL_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_GET_FILE_INFO_HIT_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_HTTP_SERVER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_HTTP_SERVER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_HTTP_SERVER_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_HTTP_SERVER_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_ID_FIELD_NUMBER - Static variable in class alluxio.proto.meta.Block.BlockLocation
 
WORKER_IDENTITY_UUID - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_IDENTITY_UUID - Static variable in class alluxio.conf.PropertyKey
 
WORKER_IDENTITY_UUID_FILE_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_IDENTITY_UUID_FILE_PATH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_KEYTAB_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_KEYTAB_FILE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_LIST_STATUS_EXTERNAL_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_LIST_STATUS_HIT_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_MASTER_CONNECT_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MASTER_CONNECT_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MASTER_PERIODICAL_RPC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MASTER_PERIODICAL_RPC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MASTER_REGISTRATION_SUCCESS_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_MEMBERSHIP_MANAGER_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MEMBERSHIP_MANAGER_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MEMORY_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_GRPC_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_GRPC_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_GRPC_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_GRPC_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BACKLOG - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BACKLOG - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BOSS_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BOSS_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BUFFER_RECEIVE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BUFFER_RECEIVE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BUFFER_SEND - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BUFFER_SEND - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_FILE_TRANSFER_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_FILE_TRANSFER_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_RPC_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_RPC_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_SHUTDOWN_QUIET_PERIOD - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_SHUTDOWN_QUIET_PERIOD - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_UFS_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_UFS_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WATERMARK_HIGH - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WATERMARK_HIGH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WATERMARK_LOW - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WATERMARK_LOW - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_PACKET_SENDING_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_PACKET_SENDING_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_READER_BUFFER_POOLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_READER_BUFFER_POOLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_READER_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_READER_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_READER_MAX_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_READER_MAX_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_DIRS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_DIRS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_SIZES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_SIZES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PIN_LIST_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey
 
WORKER_QUIET_THRESHOLD - Static variable in class alluxio.cli.fsadmin.command.DecommissionWorkerCommand.WorkerStatus
 
WORKER_RAMDISK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RAMDISK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_COMPLETE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_COMPLETE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_DEADLINE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_DEADLINE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_TO_ALL_MASTERS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_TO_ALL_MASTERS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REMOTE_IO_SLOW_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REMOTE_IO_SLOW_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REST_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REST_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_QUEUE_LENGTH - Static variable in class alluxio.metrics.MetricKey
 
WORKER_RPC_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_RPC_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_S3_ASYNC_HEAVY_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_ASYNC_HEAVY_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_ASYNC_HEAVY_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_ASYNC_HEAVY_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_ASYNC_HEAVY_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_ASYNC_HEAVY_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_ASYNC_LIGHT_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_ASYNC_LIGHT_POOL_CORE_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_ASYNC_LIGHT_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_ASYNC_LIGHT_POOL_MAXIMUM_THREAD_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_ASYNC_LIGHT_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_ASYNC_LIGHT_POOL_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_ASYNC_PROCESS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_ASYNC_PROCESS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_S3_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_REST_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_S3_REST_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_SPACE_RESERVER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_STARTUP_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_STARTUP_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_STATIC_MEMBERSHIP_MANAGER_CONFIG_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_STATIC_MEMBERSHIP_MANAGER_CONFIG_FILE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_STORAGE_HEALTH - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_BLOCK_OPEN_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_BLOCK_OPEN_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_EXPIRARTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_USED_BYTES_ON_TIERS_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
WORKER_USED_BYTES_ON_TIERS = 9;
WORKER_USED_BYTES_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
WORKER_USED_BYTES = 8;
WORKER_VALUE - Static variable in enum alluxio.grpc.Scope
WORKER = 2;
WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
WORKER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKERADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockLocation
 
WorkerAddressConverter() - Constructor for class alluxio.cli.TestRunner.WorkerAddressConverter
 
WORKERADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
workerAddressListToString(Collection<WorkerNetAddress>) - Static method in class alluxio.cli.fsadmin.command.WorkerAddressUtils
Convert a list of worker addresses to string.
WorkerAddressUtils - Class in alluxio.cli.fsadmin.command
A util class for worker address -> string conversion.
WorkerAddressUtils() - Constructor for class alluxio.cli.fsadmin.command.WorkerAddressUtils
 
WorkerAssignPolicy - Class in alluxio.master.job
The worker assign policy.
WorkerAssignPolicy() - Constructor for class alluxio.master.job.WorkerAssignPolicy
 
WorkerBenchCoarseDataPoint - Class in alluxio.stress.worker
One coarseDataPoint captures and merges the performance of I/O operations in a specified window.
WorkerBenchCoarseDataPoint(Long, Long) - Constructor for class alluxio.stress.worker.WorkerBenchCoarseDataPoint
Creates a coarse data point without data and throughput arrays.
WorkerBenchCoarseDataPoint(Long, Long, List<WorkerBenchDataPoint>, List<Long>) - Constructor for class alluxio.stress.worker.WorkerBenchCoarseDataPoint
Creates a coarse data point with data and throughput arrays.
WorkerBenchCoarseDataPointDeserializer - Class in alluxio.stress.worker
A deserializer converting WorkerBenchCoarseDataPoint from JSON.
WorkerBenchCoarseDataPointDeserializer() - Constructor for class alluxio.stress.worker.WorkerBenchCoarseDataPointDeserializer
 
WorkerBenchDataPoint - Class in alluxio.stress.worker
One data point captures the information we collect from one I/O operation to a worker.
WorkerBenchDataPoint(long, long) - Constructor for class alluxio.stress.worker.WorkerBenchDataPoint
 
WorkerBenchDataPoint() - Constructor for class alluxio.stress.worker.WorkerBenchDataPoint
A constructor without parameters.
WorkerBenchDataPointDeserializer - Class in alluxio.stress.worker
A deserializer converting WorkerBenchDataPoint from JSON.
WorkerBenchDataPointDeserializer() - Constructor for class alluxio.stress.worker.WorkerBenchDataPointDeserializer
 
WorkerBenchParameters - Class in alluxio.stress.worker
This holds all the parameters.
WorkerBenchParameters() - Constructor for class alluxio.stress.worker.WorkerBenchParameters
 
WorkerBenchSummary - Class in alluxio.stress.worker
The summary for the worker stress tests.
WorkerBenchSummary() - Constructor for class alluxio.stress.worker.WorkerBenchSummary
Creates an instance.
WorkerBenchSummary(WorkerBenchTaskResult, Map<String, WorkerBenchTaskResult>) - Constructor for class alluxio.stress.worker.WorkerBenchSummary
Creates an instance.
WorkerBenchSummary.GraphGenerator - Class in alluxio.stress.worker
The graph generator for this summary.
WorkerBenchTaskResult - Class in alluxio.stress.worker
The task results for the worker stress test.
WorkerBenchTaskResult() - Constructor for class alluxio.stress.worker.WorkerBenchTaskResult
Creates an instance.
workerEventLoopGroup(EventLoopGroup) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the worker EventLoopGroup.
WorkerHealthCheckClient - Class in alluxio.worker
WorkerHealthCheckClient check if worker is serving RPC.
WorkerHealthCheckClient(InetSocketAddress, Supplier<RetryPolicy>, AlluxioConfiguration) - Constructor for class alluxio.worker.WorkerHealthCheckClient
Creates a worker health check client.
WORKERHEALTHS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetAllWorkerHealthPResponse
 
workerHeartbeat(long, Map<String, Long>, Map<String, Long>, List<Long>, Map<Block.BlockLocation, List<Long>>, Map<String, StorageList>, List<Metric>) - Method in interface alluxio.master.block.BlockMaster
Updates metadata when a worker periodically heartbeats with the master.
workerHeartbeat(long, Map<String, Long>, Map<String, Long>, List<Long>, Map<Block.BlockLocation, List<Long>>, Map<String, StorageList>, List<Metric>) - Method in class alluxio.master.block.DefaultBlockMaster
 
workerHeartbeat(long, List<Long>, WorkerHeartbeatContext) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
workerHeartbeat(long, List<Long>, WorkerHeartbeatContext) - Method in interface alluxio.master.file.FileSystemMaster
Instructs a worker to persist the files.
workerHeartbeat(JobWorkerHealth, List<TaskInfo>) - Method in class alluxio.master.job.JobMaster
Updates the tasks' status when a worker periodically heartbeats with the master, and sends the commands for the worker to execute.
workerHeartbeat(String, List<Metric>) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
workerHeartbeat(String, List<Metric>) - Method in interface alluxio.master.metrics.MetricsMaster
Handles the worker heartbeat and puts the metrics from an instance with a source name.
WorkerHeartbeatContext - Class in alluxio.master.file.contexts
Used to merge and wrap FileSystemHeartbeatPOptions.
WORKERHOST_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
WORKERHOSTNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.DecommissionWorkerPOptions
 
WORKERHOSTNAME_FIELD_NUMBER - Static variable in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockLocation
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.FileSystemHeartbeatPRequest
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetRegisterLeasePRequest
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetRegisterLeasePResponse
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerIdPResponse
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.JobWorkerHealth
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.NotifyWorkerIdPRequest
 
WORKERID_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterWorkerPRequest
 
WorkerIdentity - Class in alluxio.grpc
opaque identifier that uniquely identifies a worker
WorkerIdentity - Class in alluxio.wire
An identifier that uniquely identifies a worker.
WorkerIdentity.Builder - Class in alluxio.grpc
opaque identifier that uniquely identifies a worker
WorkerIdentity.Parsers - Class in alluxio.wire
Parsers for worker identity.
WorkerIdentity.ParserV0 - Class in alluxio.wire
Parser for legacy long-based worker IDs.
WorkerIdentity.ParserV1 - Class in alluxio.wire
Parser for WorkerIdentity that is based on a UUID.
WorkerIdentityOrBuilder - Interface in alluxio.grpc
 
WorkerIdentityProvider - Class in alluxio.worker.modules
Provider that resolves worker identities from configuration, persisted storage, or automatically generates a new one.
WorkerIdentityProvider(AlluxioConfiguration) - Constructor for class alluxio.worker.modules.WorkerIdentityProvider
 
WorkerIdentityProvider(AlluxioConfiguration, Supplier<UUID>) - Constructor for class alluxio.worker.modules.WorkerIdentityProvider
 
WorkerInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.WorkerInfo
WorkerInfo - Class in alluxio.wire
The worker information.
WorkerInfo() - Constructor for class alluxio.wire.WorkerInfo
 
WorkerInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.WorkerInfo
WorkerInfo.LastContactSecComparator - Class in alluxio.wire
Determine order from most recently contacted to least recently contacted.
WorkerInfoField - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.block.WorkerInfoField
WorkerInfoHub(Scheduler, WorkerProvider) - Constructor for class alluxio.master.scheduler.Scheduler.WorkerInfoHub
Constructor.
WorkerInfoIdentity(WorkerInfo) - Constructor for class alluxio.master.scheduler.Scheduler.WorkerInfoIdentity
Constructor for WorkerInfoIdentity from WorkerInfo.
WorkerInfoOrBuilder - Interface in alluxio.grpc
 
WORKERINFOS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerInfoListPResponse
 
WorkerInfoUtil - Class in alluxio.client.block.util
The util class for getting the worker info.
WorkerInfoUtil() - Constructor for class alluxio.client.block.util.WorkerInfoUtil
 
workerListToString(Set<BlockWorkerInfo>) - Static method in class alluxio.cli.fsadmin.command.WorkerAddressUtils
Converts a set of worker metadata to string.
WORKERLOCATION_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
WorkerLocationPolicy - Interface in alluxio.client.file.dora
Interface for determining the Alluxio worker location to serve a read or write request.
WorkerLocationPolicy.Factory - Class in alluxio.client.file.dora
The factory for the WorkerLocationPolicy.
WorkerLostStorageInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.WorkerLostStorageInfo
WorkerLostStorageInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.WorkerLostStorageInfo
WORKERLOSTSTORAGEINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerLostStoragePResponse
 
WorkerLostStorageInfoOrBuilder - Interface in alluxio.grpc
 
WorkerMetaLock - Class in alluxio.master.block.meta
This class manages the logic of locking multiple sections in MasterWorkerInfo properly.
WorkerMetaLockSection - Enum in alluxio.master.block.meta
Enum for the locks in MasterWorkerInfo.
workerMetrics(FileSystemContext) - Static method in class alluxio.cli.bundler.command.CollectMetricsCommand
Get metrics from each worker.
WorkerNetAddress - Class in alluxio.grpc
Address information about workers.
WorkerNetAddress - Class in alluxio.wire
The network address of a worker.
WorkerNetAddress() - Constructor for class alluxio.wire.WorkerNetAddress
Creates a new instance of WorkerNetAddress.
WorkerNetAddress.Builder - Class in alluxio.grpc
Address information about workers.
WORKERNETADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerIdPRequest
 
WORKERNETADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.NotifyWorkerIdPRequest
 
WORKERNETADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.RegisterJobWorkerPRequest
 
WorkerNetAddressOrBuilder - Interface in alluxio.grpc
 
WorkerOutOfSpaceException - Exception in alluxio.exception
The exception thrown when a worker is out of space.
WorkerOutOfSpaceException(String) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified detail message.
WorkerOutOfSpaceException(String, Throwable) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified detail message and cause.
WorkerOutOfSpaceException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified exception message and multiple parameters.
WorkerOutOfSpaceException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
WorkerProcess - Interface in alluxio.worker
A worker in the Alluxio system.
WorkerProcess.Factory - Class in alluxio.worker
Factory for creating WorkerProcess.
WorkerProvider - Interface in alluxio.master.scheduler
Interface for providing worker information and client.
WorkerRange - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.block.WorkerRange
WORKERRANGE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerReportPOptions
 
workerRegister(long, List<String>, Map<String, Long>, Map<String, Long>, Map<Block.BlockLocation, List<Long>>, Map<String, StorageList>, RegisterWorkerPOptions) - Method in interface alluxio.master.block.BlockMaster
Updates metadata when a worker registers with the master.
workerRegister(long, List<String>, Map<String, Long>, Map<String, Long>, Map<Block.BlockLocation, List<Long>>, Map<String, StorageList>, RegisterWorkerPOptions) - Method in class alluxio.master.block.DefaultBlockMaster
 
workerRegisterBatch(WorkerRegisterContext, RegisterWorkerPRequest) - Method in class alluxio.master.block.DefaultBlockMaster
 
WorkerRegisterContext - Class in alluxio.master.block
This holds the context while the worker is registering with the master with a stream.
workerRegisterFinish(WorkerRegisterContext) - Method in interface alluxio.master.block.BlockMaster
Completes the worker registration stream.
workerRegisterFinish(WorkerRegisterContext) - Method in class alluxio.master.block.DefaultBlockMaster
 
workerRegisterStart(WorkerRegisterContext, RegisterWorkerPRequest) - Method in class alluxio.master.block.DefaultBlockMaster
 
workerRegisterStream(WorkerRegisterContext, RegisterWorkerPRequest, boolean) - Method in interface alluxio.master.block.BlockMaster
Handles messages in a register stream.
workerRegisterStream(WorkerRegisterContext, RegisterWorkerPRequest, boolean) - Method in class alluxio.master.block.DefaultBlockMaster
 
WorkerRegisterStreamGCExecutor() - Constructor for class alluxio.master.block.DefaultBlockMaster.WorkerRegisterStreamGCExecutor
 
WorkerRegistry - Class in alluxio.worker
A worker registry.
WorkerRegistry() - Constructor for class alluxio.worker.WorkerRegistry
Creates a new instance of WorkerRegistry.
WorkerServiceEntity - Class in alluxio.membership
Entity class including all the information to register to Etcd when using EtcdMembershipManager.
WorkerServiceEntity() - Constructor for class alluxio.membership.WorkerServiceEntity
CTOR for WorkerServiceEntity.
WorkerServiceEntity(WorkerNetAddress) - Constructor for class alluxio.membership.WorkerServiceEntity
CTOR for WorkerServiceEntity with given WorkerNetAddress.
WorkerState - Enum in alluxio.master
The worker state maintained by master.
WorkerStatusCommand - Class in alluxio.cli.fsadmin.nodes
Command to print worker nodes status.
WorkerStatusCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.nodes.WorkerStatusCommand
 
WorkerUfsManager - Class in alluxio.underfs
The default implementation of UfsManager to manage the ufs used by different worker services.
WorkerUfsManager(FileSystemMasterClient) - Constructor for class alluxio.underfs.WorkerUfsManager
Constructs an instance of WorkerUfsManager.
WorkerUsageMeta - Class in alluxio.master.block.meta
An object representation of fields relevant to worker usage and capacity.
WorkerUsageMeta() - Constructor for class alluxio.master.block.meta.WorkerUsageMeta
 
WORKERWEBPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.DecommissionWorkerPOptions
 
WORKERWEBPORT_FIELD_NUMBER - Static variable in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
WorkerWebServer - Class in alluxio.web
The Alluxio worker web server.
WorkerWebServer(InetSocketAddress, WorkerProcess, DataWorker) - Constructor for class alluxio.web.WorkerWebServer
Creates a new instance of WorkerWebServer.
WorkerWebServer(InetSocketAddress, WorkerProcess, DataWorker, FileSystem) - Constructor for class alluxio.web.WorkerWebServer
Creates a new instance of WorkerWebServer.
WorkerWebUIBlockInfo - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIBlockInfo() - Constructor for class alluxio.wire.WorkerWebUIBlockInfo
Creates a new instance of WorkerWebUIBlockInfo.
WorkerWebUIConfiguration - Class in alluxio.wire
Alluxio WebUI configuration information.
WorkerWebUIConfiguration() - Constructor for class alluxio.wire.WorkerWebUIConfiguration
Creates a new instance of WorkerWebUIConfiguration.
WorkerWebUIInit - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIInit() - Constructor for class alluxio.wire.WorkerWebUIInit
Creates a new instance of WorkerWebUIInit.
WorkerWebUILogs - Class in alluxio.wire
Alluxio WebUI logs information.
WorkerWebUILogs() - Constructor for class alluxio.wire.WorkerWebUILogs
Creates a new instance of MasterWebUIWorkers.
WorkerWebUIMetrics - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIMetrics() - Constructor for class alluxio.wire.WorkerWebUIMetrics
Creates a new instance of WorkerWebUIMetrics.
WorkerWebUIOperations - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIOperations() - Constructor for class alluxio.wire.WorkerWebUIOperations
Creates a new instance of WorkerWebUIInit.
WorkerWebUIOverview - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIOverview() - Constructor for class alluxio.wire.WorkerWebUIOverview
Creates a new instance of WorkerWebUIOverview.
WORKFLOW_VALUE - Static variable in enum alluxio.grpc.JobType
WORKFLOW = 3;
WorkflowConfig - Interface in alluxio.job.workflow
A workflow configuration.
WorkflowExecution - Class in alluxio.job.workflow
Execution details of a workflow.
WorkflowExecution() - Constructor for class alluxio.job.workflow.WorkflowExecution
Default constructor.
WorkflowExecutionFactory<T extends WorkflowConfig> - Interface in alluxio.job.workflow
The workflow execution factory.
WorkflowExecutionRegistry - Enum in alluxio.job.workflow
Registry for WorkflowExecution.
WorkflowInfo - Class in alluxio.job.wire
The workflow description.
WorkflowInfo(long, String, Status, long, String, String, List<JobInfo>) - Constructor for class alluxio.job.wire.WorkflowInfo
Default constructor.
WorkflowInfo(JobInfo) - Constructor for class alluxio.job.wire.WorkflowInfo
Constructor from the proto object.
WorkflowTracker - Class in alluxio.master.job.workflow
WorkflowTracker(JobMaster) - Constructor for class alluxio.master.job.workflow.WorkflowTracker
Constructor for WorkflowTracker.
wrap(InodeView) - Static method in class alluxio.master.file.meta.Inode
Wraps an InodeView, providing read-only access.
wrap(byte[], int, int) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
write(int) - Method in class alluxio.client.file.DoraFileOutStream
 
write(byte[]) - Method in class alluxio.client.file.DoraFileOutStream
 
write(byte[], int, int) - Method in class alluxio.client.file.DoraFileOutStream
 
write(int) - Method in class alluxio.client.file.ufs.DoraOutStream
 
write(int) - Method in class alluxio.client.file.ufs.UfsFileOutStream
 
write(byte[]) - Method in class alluxio.client.file.ufs.UfsFileOutStream
 
write(byte[], int, int) - Method in class alluxio.client.file.ufs.UfsFileOutStream
 
write(String, ByteBuffer, long, long, FuseFileInfo) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
write(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FuseFileInOrOutStream
 
write(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FuseFileInStream
 
write(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FuseFileOutStream
 
write(ByteBuffer, long, long) - Method in interface alluxio.fuse.file.FuseFileStream
Writes data to the stream.
write(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FusePositionReader
 
write(ByteBuffer, long, long) - Method in class alluxio.fuse.file.FusePositionReadOrOutStream
 
write(String, ByteBuffer, long, long, FuseFileInfo) - Method in class alluxio.fuse.StackFS
 
write(String, ByteBuffer, long, long, FuseFileInfo) - Method in interface alluxio.jnifuse.FuseFileSystem
 
write(int) - Method in class alluxio.master.journal.checkpoint.OptimizedCheckpointOutputStream
 
write(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalWriter
Writes an entry.
write(Journal.JournalEntry) - Method in class alluxio.master.journal.raft.RaftJournalWriter
 
write(Journal.JournalEntry) - Method in class alluxio.master.journal.ufs.UfsJournalLogWriter
 
write(Journal.JournalEntry) - Method in interface alluxio.master.journalv0.JournalOutputStream
Writes a Journal.JournalEntry to the journal.
write(Journal.JournalEntry) - Method in interface alluxio.master.journalv0.JournalWriter
Writes an entry to the current log stream.
write(Journal.JournalEntry) - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter.EntryOutputStream
The given entry should not have its sequence number set.
write(Journal.JournalEntry) - Method in class alluxio.master.journalv0.ufs.UfsJournalWriter
 
WRITE - Static variable in class alluxio.proxy.StreamsRestServiceHandler
 
write(Integer, InputStream) - Method in class alluxio.proxy.StreamsRestServiceHandler
 
write(int) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(byte[]) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(int) - Method in class alluxio.underfs.cephfs.CephOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.cephfs.CephOutputStream
 
write(int) - Method in class alluxio.underfs.cos.COSOutputStream
Writes the given bytes to this output stream.
write(byte[]) - Method in class alluxio.underfs.cos.COSOutputStream
Writes the given byte array to this output stream.
write(byte[], int, int) - Method in class alluxio.underfs.cos.COSOutputStream
Writes the given number of bytes from the given byte array starting at the given offset to this output stream.
write(int) - Method in class alluxio.underfs.gcs.GCSOutputStream
 
write(byte[]) - Method in class alluxio.underfs.gcs.GCSOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.gcs.GCSOutputStream
 
write(int) - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
 
write(byte[]) - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.gcs.v2.GCSV2OutputStream
 
write(int) - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
write(byte[]) - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.hdfs.HdfsUnderFileOutputStream
 
write(int) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
write(byte[]) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
write(int) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
write(byte[]) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
write(int) - Method in class alluxio.underfs.obs.OBSOutputStream
Writes the given bytes to this output stream.
write(byte[]) - Method in class alluxio.underfs.obs.OBSOutputStream
Writes the given byte array to this output stream.
write(byte[], int, int) - Method in class alluxio.underfs.obs.OBSOutputStream
Writes the given number of bytes from the given byte array starting at the given offset to this output stream.
write(int) - Method in class alluxio.underfs.oss.OSSOutputStream
Writes the given bytes to this output stream.
write(byte[]) - Method in class alluxio.underfs.oss.OSSOutputStream
Writes the given byte array to this output stream.
write(byte[], int, int) - Method in class alluxio.underfs.oss.OSSOutputStream
Writes the given number of bytes from the given byte array starting at the given offset to this output stream.
write(int) - Method in class alluxio.underfs.s3a.S3AOutputStream
 
write(byte[]) - Method in class alluxio.underfs.s3a.S3AOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.s3a.S3AOutputStream
 
write(Path, OutputStream) - Method in interface alluxio.util.compression.DirectoryMarshaller
Writes the contents of path ot outputStream such that it can be read by DirectoryMarshaller.read(Path, InputStream).
write(Path, OutputStream) - Method in class alluxio.util.compression.GzipMarshaller
 
write(Path, OutputStream) - Method in class alluxio.util.compression.NoCompressionMarshaller
 
write(Path, OutputStream) - Method in class alluxio.util.compression.TarGzMarshaller
 
WRITE_EXECUTE_VALUE - Static variable in enum alluxio.grpc.Bits
WRITE_EXECUTE = 4;
WRITE_FILE_ONCE_MAX_BYTES - Static variable in class alluxio.stress.StressConstants
 
WRITE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyRequest
 
WRITE_OPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveRequest
 
WRITE_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.WriteOptions
 
WRITE_TYPE_OPTION_NAME - Static variable in class alluxio.stress.common.FileSystemParameters
 
WRITE_VALUE - Static variable in enum alluxio.grpc.Bits
WRITE = 3;
Write_VALUE - Static variable in enum alluxio.grpc.PAclAction
Write = 1;
WRITE_VALUE - Static variable in enum alluxio.proto.shared.Acl.AclAction
WRITE = 1;
writeBlock(StreamObserver<WriteResponse>) - Method in interface alluxio.client.block.stream.BlockWorkerClient
Writes a block to the worker asynchronously.
writeBlock(StreamObserver<WriteResponse>) - Method in class alluxio.client.block.stream.DefaultBlockWorkerClient
 
writeBlock(StreamObserver<WriteResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
writeBlock(StreamObserver<WriteResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
writeBuf(UfsFileWriteRequestContext, StreamObserver<WriteResponse>, DataBuffer, long) - Method in class alluxio.worker.grpc.UfsFileWriteHandler
 
writeBuf(BlockWriteRequestContext, Channel, ByteBuf, long) - Method in class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
 
writeBuf(UfsFileWriteRequestContext, Channel, ByteBuf, long) - Method in class alluxio.worker.netty.UfsFileWriteHandler.UfsFilePacketWriter
 
writeBufferToFile(String, byte[]) - Static method in class alluxio.util.io.BufferUtils
Writes buffer to the given file path.
writeByte(byte[], int, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output byte array at the given offset.
writeByte(ByteBuffer, int, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output byte buffer at the given offset.
writeByte(OutputStream, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output stream.
writeBytes(byte[], int, int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
writeBytes(ByteBuf) - Method in class alluxio.file.ByteArrayTargetBuffer
 
writeBytes(byte[], int, int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
writeBytes(ByteBuf) - Method in class alluxio.file.ByteBufferTargetBuffer
 
writeBytes(byte[], int, int) - Method in class alluxio.file.NettyBufTargetBuffer
 
writeBytes(ByteBuf) - Method in class alluxio.file.NettyBufTargetBuffer
 
writeBytes(byte[], int, int) - Method in interface alluxio.file.ReadTargetBuffer
 
writeBytes(ByteBuf) - Method in interface alluxio.file.ReadTargetBuffer
 
writeCallback(String, ByteBuffer, long, long, ByteBuffer) - Method in class alluxio.jnifuse.AbstractFuseFileSystem
 
writeChunk(ByteBuf) - Method in class alluxio.client.block.stream.BlockWorkerDataWriter
 
writeChunk(ByteBuf) - Method in interface alluxio.client.block.stream.DataWriter
Writes a chunk.
writeChunk(ByteBuf) - Method in class alluxio.client.block.stream.GrpcDataWriter
 
writeChunk(ByteBuf) - Method in class alluxio.client.block.stream.NettyDataWriter
 
writeChunk(byte[], int, int) - Method in class alluxio.client.file.dora.netty.NettyDataWriter
Write chunk by sending a write request.
writeChunk(ByteBuf) - Method in class alluxio.client.file.dora.netty.NettyDataWriter
 
writeCSVFile(Collection<? extends PropertyKey>, String) - Static method in class alluxio.cli.docgen.ConfigurationDocGenerator
Writes property key to csv files.
writeInode(MutableInode<?>) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
writeInode(MutableInode<?>) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
writeInode(MutableInode<?>) - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
Adds an inode to the write batch.
writeInode(MutableInode<?>) - Method in interface alluxio.master.metastore.InodeStore
Adds the given inode, or overwrites it if it already exists.
writeInode(MutableInode<?>) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
writeInt(byte[], int, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output byte array at the given offset.
writeInt(ByteBuffer, int, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output byte buffer at the given offset.
writeInt(OutputStream, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output stream.
writeInternal(String, ByteBuffer, long, long, long) - Method in class alluxio.fuse.AlluxioJniFuseFileSystem
 
writeJournalEntryCheckpoint(OutputStream, JournalEntryIterable) - Static method in class alluxio.master.journal.JournalUtils
Writes a checkpoint of the entries in the given iterable.
writeLock(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Exclusively acquires the lock of the bucket, blocking if necessary until available.
writeLock(int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Exclusively acquires the locks of two buckets, blocking if necessary until available.
writeLock(int, int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Exclusively acquires the locks of three buckets, blocking if necessary until available.
writeLock() - Method in class alluxio.concurrent.ClientRWLock
 
writeLockSegment(int) - Method in class alluxio.client.file.cache.cuckoofilter.SegmentedLock
Exclusively acquires the lock of the ith segment, blocking if necessary until available.
writeLong(byte[], int, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output byte array at the given offset.
writeLong(OutputStream, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output stream.
writeNewInode(MutableInode<?>) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
writeNewInode(MutableInode<?>) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
writeNewInode(MutableInode<?>) - Method in interface alluxio.master.metastore.InodeStore
Adds a new inode.
writeObject(BufferOutput<?>, Serializer) - Method in class alluxio.master.backup.BackupHandshakeMessage
 
writeObject(BufferOutput<?>, Serializer) - Method in class alluxio.master.backup.BackupHeartbeatMessage
 
writeObject(BufferOutput<?>, Serializer) - Method in class alluxio.master.backup.BackupRequestMessage
 
writeObject(BufferOutput<?>, Serializer) - Method in class alluxio.master.backup.BackupSuspendMessage
 
WriteOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.WriteOptions
WriteOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.WriteOptions
WriteOptionsOrBuilder - Interface in alluxio.grpc
 
writePartition() - Method in class alluxio.examples.Performance.AlluxioWriterWorker
Writes a partition.
WritePType - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.file.WritePType
WRITER_EXECUTOR - Static variable in class alluxio.worker.grpc.GrpcExecutors
 
WRITER_EXECUTOR - Static variable in class alluxio.worker.netty.NettyExecutors
 
WriteRequest - Class in alluxio.grpc
The write request.
WriteRequest - Class in alluxio.worker.grpc
Represents a write request received from gRPC channel.
WriteRequest.Builder - Class in alluxio.grpc
The write request.
WriteRequest.ValueCase - Enum in alluxio.grpc
 
WriteRequestCommand - Class in alluxio.grpc
The write request command.
WriteRequestCommand.Builder - Class in alluxio.grpc
The write request command.
WriteRequestCommandOrBuilder - Interface in alluxio.grpc
 
WriteRequestContext<T extends WriteRequest> - Class in alluxio.worker.grpc
Represents the context of a write request received from gRPC stream.
WriteRequestContext(T) - Constructor for class alluxio.worker.grpc.WriteRequestContext
 
WriteRequestContext<T extends alluxio.worker.netty.WriteRequest> - Class in alluxio.worker.netty
Represents the context of a write request received from netty channel.
WriteRequestContext(T) - Constructor for class alluxio.worker.netty.WriteRequestContext
 
WriteRequestMarshaller - Class in alluxio.grpc
Marshaller for WriteRequest.
WriteRequestMarshaller() - Constructor for class alluxio.grpc.WriteRequestMarshaller
WriteRequestOrBuilder - Interface in alluxio.grpc
 
WriteResponse - Class in alluxio.grpc
The write response.
WriteResponse.Builder - Class in alluxio.grpc
The write response.
WriteResponseOrBuilder - Interface in alluxio.grpc
 
writeShort(byte[], int, short) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific short value (2 bytes) to the output byte buffer at the given offset.
writeShort(OutputStream, short) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific short value (2 bytes) to the output stream.
writeTag(int, int, int) - Method in interface alluxio.client.file.cache.cuckoofilter.CuckooTable
Set the value of tag in specified position.
writeTag(int, int, int) - Method in class alluxio.client.file.cache.cuckoofilter.SimpleCuckooTable
 
writeTarGz(Path, OutputStream, int) - Static method in class alluxio.util.compression.TarUtils
Creates a gzipped tar archive from the given path, streaming the data to the give output stream.
WRITETIER_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ActionInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.AddPolicyPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.AddPolicyPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.AddPolicyPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.AddQuorumServerRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.AsyncCacheRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.AsyncCacheResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BackupPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BackupPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BackupPStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BackupStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.Block
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockHeartbeatPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockHeartbeatPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockHeartbeatPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockIdList
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockLocation
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockMasterInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BlockStoreLocationProto
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.BuildVersion
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CacheRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CacheResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CancelPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CancelPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CancelPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CancelTaskCommand
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckAccessPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckAccessPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckAccessPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckConsistencyPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckConsistencyPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckConsistencyPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckpointPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckpointPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CheckResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.Chunk
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ClearMetricsPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ClearMetricsPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ClearMetricsRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ClearMetricsResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ClientMetrics
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CmdProgress
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CmdStatusBlock
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CmdSummary
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.Command
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CommitBlockPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CommitBlockPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CommitBlockPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CompleteFilePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CompleteFilePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CompleteFilePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ConfigCheckReport
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ConfigProperties
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ConfigProperty
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CopyJobPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CopyRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CopyResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CreateDirectoryPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CreateDirectoryPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CreateDirectoryPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CreateFilePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CreateFilePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.CreateFilePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.DecommissionWorkerPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.DecommissionWorkerPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.DeletePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.DeletePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.DeletePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.DownloadSnapshotPRequest
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.DownloadSnapshotPResponse
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ErrorInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ExistsPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ExistsPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ExistsPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.File
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileBlockInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileFailure
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileSystemCommand
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileSystemCommandOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FreePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FreePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FreePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FreeWorkerRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FreeWorkerResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.FsOpPId
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetActionInfoOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetActionInfoRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetActionInfoResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetAllMasterStatusPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetAllMasterStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetAllMasterStatusPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetBlockInfoPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetBlockInfoPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetBlockInfoPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCapacityBytesPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCapacityBytesPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCmdStatusOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCmdStatusRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetCmdStatusResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetConfigHashPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetConfigHashPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetConfigReportPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetConfigReportPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetConfigurationPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetConfigurationPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetFileInfoPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetFileInfoPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetFileInfoPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetFilePathPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetFilePathPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobMasterIdPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobMasterIdPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobMasterIdPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobProgressPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobProgressPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobStatusPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetJobStatusPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMasterIdPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMasterIdPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMasterIdPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMasterInfoPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMasterInfoPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMetricsPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMetricsPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMountIdPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMountIdPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMountTablePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetMountTablePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetNodeStatePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetNodeStatePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPolicyStatusPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPolicyStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetPolicyStatusPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetQuorumInfoPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetQuorumInfoPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetQuorumInfoPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetRegisterLeasePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetRegisterLeasePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetRegisterLeasePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetServiceVersionPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetServiceVersionPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetSnapshotInfoRequest
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetSnapshotInfoResponse
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetSnapshotRequest
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetStateLockHoldersPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetStateLockHoldersPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetStateLockHoldersPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetStatusPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetStatusPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetUfsInfoPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetUfsInfoPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetUfsInfoPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetUsedBytesPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetUsedBytesPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerIdPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerIdPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerIdPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerInfoListPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerInfoListPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.GetWorkerReportPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.InconsistentProperties
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.InconsistentProperty
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.InconsistentPropertyValues
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobCommand
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobDescription
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobHeartbeatPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobHeartbeatPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobHeartbeatPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobMasterStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobProgress
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobProgressPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobServiceSummary
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobStatusBlock
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobUnused
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JobWorkerHealth
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JournalQueryRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.JournalQueryResponse
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListAllPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListAllPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListAllPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListPolicyPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListPolicyPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListPolicyPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListProxyStatusPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListProxyStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListProxyStatusPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPartialPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPartialPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPartialPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ListStatusPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadFileFailure
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadFileRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadFileResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadJobPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadMetadataPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LoadResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.LocationBlockIdListEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MasterHeartbeatPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MasterHeartbeatPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MasterHeartbeatPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MasterInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MasterVersion
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MessagingRequestHeader
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MessagingResponseHeader
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.Metric
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MetricsHeartbeatPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MetricsHeartbeatPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MetricsHeartbeatPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MetricValue
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MountPointInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MountPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MountPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MountPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MoveBlockRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MoveBlockResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MoveJobPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MoveRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.MoveResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.NeedsSyncRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.NeedsSyncResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.NetAddress
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.NotifyWorkerIdPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.NotifyWorkerIdPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.NotifyWorkerIdPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.OpenFilePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.PAcl
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.PAclEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.PersistCommandOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.PersistFile
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.PMode
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.PolicyInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.PolicyStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ProxyHeartbeatPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ProxyHeartbeatPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ProxyHeartbeatPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ProxyStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.QuorumServerInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ReadRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ReadResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterCommand
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterJobMasterPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterJobMasterPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterJobMasterPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterJobWorkerPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterJobWorkerPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterJobWorkerPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterMasterPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterMasterPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterMasterPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterWorkerPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterWorkerPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RegisterWorkerPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemoveBlockRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemoveBlockResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePathConfigurationPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePathConfigurationPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePathConfigurationPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePolicyPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePolicyPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemovePolicyPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemoveQuorumServerPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemoveQuorumServerPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RemoveQuorumServerPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RenamePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RenamePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RenamePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ResetPrioritiesPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ResetPrioritiesPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ResetPrioritiesPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RetryInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ReverseResolvePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ReverseResolvePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.Route
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RouteFailure
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RunPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RunPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RunPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.RunTaskCommand
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.S3SyntaxOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SaslMessage
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetAclPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetAclPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetAclPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetAttributePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetAttributePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetAttributePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetPathConfigurationPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetPathConfigurationPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetPathConfigurationPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SetTaskPoolSizeCommand
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SnapshotData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SnapshotMetadata
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StatusSummary
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StopJobPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StopJobPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.StorageList
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SubmitJobPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SubmitJobPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SubmitOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SubmitRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.SubmitResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.AllOrNoneSet
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.AttachDatabasePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.AttachDatabasePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.BinaryColumnStatsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.BooleanColumnStatsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.ColumnStatisticsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.ColumnStatisticsInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.ColumnStatisticsList
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Constraint
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Database
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Date
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.DateColumnStatsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Decimal
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.DecimalColumnStatsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.DetachDatabasePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.DetachDatabasePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Domain
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.DoubleColumnStatsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.EquatableValueSet
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.FieldSchema
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.FileStatistics
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetAllTablesPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetAllTablesPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetDatabasePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetDatabasePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetTablePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetTablePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.layout.hive.SortingColumn
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.layout.hive.Storage
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.layout.hive.StorageFormat
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Layout
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.LayoutSpec
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.LongColumnStatsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Partition
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.PartitionSpec
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Range
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.RangeSet
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.ReadTablePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.ReadTablePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Schema
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.StringColumnStatsData
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.SyncDatabasePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.SyncDatabasePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.SyncStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.TableInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Transformation
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.TransformJobInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.TransformTablePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.TransformTablePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.table.Value
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TierList
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TransferLeaderMessage
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TransferLeadershipPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TransferLeadershipPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TransferLeadershipPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TransportMessage
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TriggerPolicyRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.TriggerPolicyResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UfsFileStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UfsInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UfsReadOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UfsStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UnmountPOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UnmountPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UnmountPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UpdateConfigurationPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UpdateConfigurationPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UpdateMountPRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UpdateMountPResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UpdateUfsModePOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UpdateUfsModePRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UpdateUfsModePResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UploadSnapshotPRequest
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.UploadSnapshotPResponse
Deprecated.
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WorkerIdentity
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WorkerInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WorkerLostStorageInfo
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WorkerNetAddress
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WriteOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WriteRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WriteRequestCommand
 
writeTo(CodedOutputStream) - Method in class alluxio.grpc.WriteResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.Response
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Block.BlockInfoEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.AddMountPointEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.AddSyncPointEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.CompleteFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.DeleteFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.NewBlockEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.PersistFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.RenameEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.SetAclEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.SetAttributeEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.StringPairEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.UpdateInodeEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Job.CopyJobEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Job.FileFilter
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Job.LoadJobEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Job.MoveJobEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Journal.JournalEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Journal.JournalOpPId
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.meta.Block.BlockLocation
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.meta.Block.BlockMeta
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.meta.DoraMeta.FileStatus
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.meta.InodeMeta.Inode
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.shared.Acl.AccessControlList
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.shared.Acl.AclActions
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.shared.Acl.AclEntry
 
writeTo(CodedOutputStream) - Method in class alluxio.proto.shared.Acl.NamedAclActions
 
writeToBackingStore(K, V) - Method in class alluxio.master.metastore.caching.Cache
Writes a key/value pair to the backing store.
writeToCheckpoint(File, ExecutorService) - Method in class alluxio.master.block.DefaultBlockMaster
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.file.meta.CheckpointedIdHashSet
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.file.meta.InodeCounter
 
writeToCheckpoint(File, ExecutorService) - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.file.meta.InodeTreePersistentState
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.file.meta.TtlBucketList
 
writeToCheckpoint(File, ExecutorService) - Method in interface alluxio.master.journal.checkpoint.Checkpointed
Writes a checkpoint to the specified directory asynchronously using the provided executor.
writeToCheckpoint(OutputStream) - Method in interface alluxio.master.journal.checkpoint.Checkpointed
Writes a checkpoint of all state to the given output stream.
writeToCheckpoint(File, ExecutorService) - Method in interface alluxio.master.journal.DelegatingJournaled
 
writeToCheckpoint(OutputStream) - Method in interface alluxio.master.journal.DelegatingJournaled
 
writeToCheckpoint(OutputStream) - Method in interface alluxio.master.journal.Journaled
 
writeToCheckpoint(File, ExecutorService) - Method in class alluxio.master.journal.JournaledGroup
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.journal.JournaledGroup
 
writeToCheckpoint(OutputStream, List<? extends Checkpointed>) - Static method in class alluxio.master.journal.JournalUtils
Writes a composite checkpoint for the given checkpointed components.
writeToCheckpoint(File, ExecutorService) - Method in interface alluxio.master.journal.NoopJournaled
 
writeToCheckpoint(OutputStream) - Method in interface alluxio.master.journal.NoopJournaled
 
writeToCheckpoint(File, ExecutorService) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
writeToCheckpoint(OutputStream) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
writeToCheckpoint(File, ExecutorService) - Method in interface alluxio.rocks.RocksCheckpointed
 
writeToCheckpoint(OutputStream) - Method in interface alluxio.rocks.RocksCheckpointed
 
writeToCheckpoint(File) - Method in class alluxio.rocks.RocksStore
Writes a checkpoint under the specified directory.
writeToCheckpoint(OutputStream) - Method in class alluxio.rocks.RocksStore
Writes a checkpoint of the database's content to the given output stream.
WriteType - Enum in alluxio.client
Write types for creating a file in Alluxio.
WRITETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyJobPOptions
 
WRITETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
WRITETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
WRITETYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveJobPOptions
 
writeYMLFile(Collection<? extends PropertyKey>, String) - Static method in class alluxio.cli.docgen.ConfigurationDocGenerator
Writes description of property key to yml files.

X

XATTR_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsStatus
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
XATTR_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
XATTR_STR_CHARSET - Static variable in class alluxio.s3.S3Constants
 
XATTR_UPDATE_STRATEGY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
XAttrPropagationStrategy - Enum in alluxio.grpc
XAttrPropagationStrategy controls the behaviour for assigning xAttr on Inodes within nested directories - NEW_PATHS: Assign xAttr for any missing nodes along the filepath - LEAF_NODE: Only assign xAttr on the leaf node of the filepath
XATTRPROPSTRAT_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
XATTRPROPSTRAT_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
XATTRUPDATESTRATEGY_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAttributePOptions
 

Z

ZipCheckpointFormat - Class in alluxio.master.journal.checkpoint
Format for checkpoints written as zip files, created by parallel compression.
ZipCheckpointFormat() - Constructor for class alluxio.master.journal.checkpoint.ZipCheckpointFormat
 
ZipCheckpointFormat.ZipCheckpointReader - Class in alluxio.master.journal.checkpoint
Reads a tarball-based checkpoint.
ZipCheckpointReader(CheckpointInputStream) - Constructor for class alluxio.master.journal.checkpoint.ZipCheckpointFormat.ZipCheckpointReader
 
ZkMasterConnectDetails(String, String) - Constructor for class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
ZkMasterInquireClient - Class in alluxio.master
Utility to get leader from zookeeper.
ZkMasterInquireClient.ZkMasterConnectDetails - Class in alluxio.master
Details used to connect to the leader Alluxio master via Zookeeper.
ZOOKEEPER_ADDRESS - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_ADDRESS - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_ADDRESSES_VALUE - Static variable in enum alluxio.grpc.MasterInfoField
ZOOKEEPER_ADDRESSES = 9;
ZOOKEEPER_AUTH - Static variable in interface alluxio.uri.Authority
 
ZOOKEEPER_AUTH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_AUTH_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_CONNECTION_POLICY_SESSION - Static variable in class alluxio.multi.process.PortCoordination
 
ZOOKEEPER_CONNECTION_POLICY_STANDARD - Static variable in class alluxio.multi.process.PortCoordination
 
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_FAILURE - Static variable in class alluxio.multi.process.PortCoordination
 
ZOOKEEPER_JOB_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_JOB_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_JOB_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_JOB_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_LEADER_CONNECTION_ERROR_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_LEADER_CONNECTION_ERROR_POLICY - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_LEADER_INQUIRY_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_LEADER_INQUIRY_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_URI - Static variable in class alluxio.multi.process.PortCoordination
 
ZOOKEEPERADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterInfo
 
ZookeeperAuthority - Class in alluxio.uri
ZookeeperAuthority supports authority containing Zookeeper addresses.
ZookeeperAuthority(String) - Constructor for class alluxio.uri.ZookeeperAuthority
 
ZookeeperConnectionErrorPolicy - Enum in alluxio.master
Defines supported connection error policies for leader election.
ZookeeperLogicalAuthority - Class in alluxio.uri
A zookeeper logical host authority implementation.
ZookeeperLogicalAuthority(String) - Constructor for class alluxio.uri.ZookeeperLogicalAuthority
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z 
Skip navigation links

Copyright © 2023. All Rights Reserved.